From 9c74add25d81c3adbc0392f4f4327ae44194ce3c Mon Sep 17 00:00:00 2001 From: Spring Operator Date: Thu, 21 Mar 2019 15:57:06 -0500 Subject: [PATCH] URL Cleanup This commit updates URLs to prefer the https protocol. Redirects are not followed to avoid accidentally expanding intentionally shortened URLs (i.e. if using a URL shortener). # Fixed URLs ## Fixed Success These URLs were switched to an https URL with a 2xx status. While the status was successful, your review is still recommended. * [ ] http://www.apache.org/licenses/ with 1 occurrences migrated to: https://www.apache.org/licenses/ ([https](https://www.apache.org/licenses/) result 200). * [ ] http://www.apache.org/licenses/LICENSE-2.0 with 1444 occurrences migrated to: https://www.apache.org/licenses/LICENSE-2.0 ([https](https://www.apache.org/licenses/LICENSE-2.0) result 200). --- CONTRIBUTING.md | 2 +- README.md | 2 +- config/sqoop-site.xml | 2 +- .../springframework/xd/documentation/AsciidocLinkChecker.java | 2 +- .../xd/documentation/ModuleOptionsReferenceDoc.java | 2 +- .../springframework/xd/documentation/ShellReferenceDoc.java | 2 +- .../integration/x/IncrementalColumnRangePartitioner.java | 2 +- .../batch/integration/x/RemoteFilePartitioner.java | 2 +- .../batch/integration/x/RemoteFileToHadoopTasklet.java | 2 +- .../batch/integration/x/TimestampFileTasklet.java | 2 +- .../batch/step/tasklet/x/AbstractProcessBuilderTasklet.java | 2 +- .../batch/step/tasklet/x/ClasspathEnvironmentProvider.java | 2 +- .../batch/step/tasklet/x/EnvironmentProvider.java | 2 +- .../x/IncrementalColumnRangePartitionerConfiguration.java | 2 +- .../integration/x/IncrementalColumnRangePartitionerTest.java | 2 +- .../batch/integration/x/RemoteFileToHadoopTaskletTests.java | 2 +- .../batch/integration/x/RemoteFileToHadoopTests.java | 2 +- .../batch/integration/x/RemoteFileToTmpTests.java | 2 +- .../springframework/xd/cassandra/CassandraConfiguration.java | 2 +- .../xd/cassandra/CassandraSinkConfiguration.java | 2 +- .../xd/cassandra/CassandraSinkOptionsMetadata.java | 2 +- .../xd/cassandra/mixins/CassandraConnectionMixin.java | 2 +- .../xd/cassandra/CassandraSinkModulePropertiesTests.java | 2 +- .../org/springframework/xd/cassandra/CassandraSinkTests.java | 2 +- .../test/java/org/springframework/xd/test/domain/Book.java | 2 +- .../springframework/xd/tcp/encdec/EncoderDecoderMixins.java | 2 +- .../integration/x/gemfire/JsonStringToObjectTransformer.java | 2 +- .../xd/gemfire/GemfireCQSourceOptionsMetadata.java | 2 +- .../org/springframework/xd/gemfire/GemfireHostPortMixin.java | 2 +- .../xd/gemfire/GemfireServerSinkModuleOptionsMetadata.java | 2 +- .../xd/gemfire/GemfireSourceOptionsMetadata.java | 2 +- .../x/gemfire/JsonStringToObjectTransformerTests.java | 2 +- .../xd/greenplum/config/GPFDistSinkOptionsMetadata.java | 2 +- .../xd/greenplum/gpfdist/AbstractGPFDistMessageHandler.java | 2 +- .../springframework/xd/greenplum/gpfdist/GPFDistCodec.java | 2 +- .../xd/greenplum/gpfdist/GPFDistMessageHandler.java | 2 +- .../springframework/xd/greenplum/gpfdist/GPFDistServer.java | 2 +- .../xd/greenplum/support/AbstractExternalTable.java | 2 +- .../org/springframework/xd/greenplum/support/ControlFile.java | 2 +- .../xd/greenplum/support/ControlFileFactoryBean.java | 2 +- .../xd/greenplum/support/DefaultGreenplumLoad.java | 2 +- .../xd/greenplum/support/DefaultLoadService.java | 2 +- .../java/org/springframework/xd/greenplum/support/Format.java | 2 +- .../xd/greenplum/support/GreenplumDataSourceFactoryBean.java | 2 +- .../springframework/xd/greenplum/support/GreenplumLoad.java | 2 +- .../springframework/xd/greenplum/support/JdbcCommands.java | 2 +- .../xd/greenplum/support/LoadConfiguration.java | 2 +- .../xd/greenplum/support/LoadConfigurationFactoryBean.java | 2 +- .../springframework/xd/greenplum/support/LoadFactoryBean.java | 2 +- .../org/springframework/xd/greenplum/support/LoadService.java | 2 +- .../java/org/springframework/xd/greenplum/support/Mode.java | 2 +- .../springframework/xd/greenplum/support/NetworkUtils.java | 2 +- .../springframework/xd/greenplum/support/ReadableTable.java | 2 +- .../xd/greenplum/support/ReadableTableFactoryBean.java | 2 +- .../springframework/xd/greenplum/support/RuntimeContext.java | 2 +- .../xd/greenplum/support/SegmentRejectType.java | 2 +- .../org/springframework/xd/greenplum/support/SqlUtils.java | 2 +- .../org/springframework/xd/greenplum/AbstractLoadTests.java | 2 +- .../test/java/org/springframework/xd/greenplum/LoadIT.java | 2 +- .../org/springframework/xd/greenplum/TestListenAddress.java | 2 +- .../test/java/org/springframework/xd/greenplum/TestUtils.java | 2 +- .../xd/greenplum/support/ControlFileTests.java | 2 +- .../greenplum/support/LoadConfigurationFactoryBeanTests.java | 2 +- .../springframework/xd/gpload/GploadEnvironmentProvider.java | 2 +- .../org/springframework/xd/gpload/GploadOptionsMetadata.java | 2 +- .../java/org/springframework/xd/gpload/GploadTasklet.java | 2 +- .../xd/header/enricher/HeaderEnricherIntegrationTests.java | 2 +- .../xd/header/enricher/HeaderEnricherModuleTests.java | 2 +- .../integration/x/http/NettyHttpInboundChannelAdapter.java | 2 +- .../integration/x/http/NettyInboundMessageConverter.java | 2 +- .../xd/http/HttpClientProcessorOptionsMetadata.java | 2 +- .../x/http/NettyHttpInboundChannelAdapterTests.java | 2 +- .../xd/jdbc/AbstractImportToJdbcOptionsMetadata.java | 2 +- .../springframework/xd/jdbc/FileJdbcJobOptionsMetadata.java | 2 +- .../java/org/springframework/xd/jdbc/JdbcConnectionMixin.java | 2 +- .../org/springframework/xd/jdbc/JdbcConnectionPoolMixin.java | 2 +- .../org/springframework/xd/jdbc/JdbcHdfsOptionsMetadata.java | 2 +- .../xd/jdbc/JdbcMessagePayloadTransformer.java | 2 +- .../xd/jdbc/JdbcSinkModuleOptionsMetadata.java | 2 +- .../xd/jdbc/JdbcSourceModuleOptionsMetadata.java | 2 +- .../xd/jdbc/NamedColumnJdbcBatchItemWriter.java | 2 +- .../springframework/xd/jdbc/NamedColumnJdbcItemReader.java | 2 +- .../xd/jdbc/NamedColumnJdbcItemReaderFactory.java | 2 +- .../xd/jdbc/ResourcesIntoJdbcJobModuleOptionsMetadata.java | 2 +- .../xd/jdbc/SingleTableDatabaseInitializer.java | 2 +- .../xd/jdbc/JdbcMessagePayloadTransformerTests.java | 2 +- .../xd/jdbc/NamedColumnJdbcItemReaderFactoryTests.java | 2 +- .../xd/jdbc/SingleTableDatabaseInitializerTests.java | 2 +- .../integration/x/kafka/AutoOffsetResetStrategy.java | 2 +- .../integration/x/kafka/InitialOffsetsFactoryBean.java | 2 +- .../integration/x/kafka/KafkaConsumerOptionsMixin.java | 2 +- .../integration/x/kafka/KafkaMessageTransformer.java | 2 +- .../integration/x/kafka/KafkaOffsetTopicOptionsMixin.java | 2 +- .../integration/x/kafka/KafkaPartitionAllocator.java | 2 +- .../integration/x/kafka/KafkaProducerOptionsMixin.java | 2 +- .../integration/x/kafka/KafkaSinkModuleOptionsMetadata.java | 2 +- .../integration/x/kafka/KafkaSourceModuleOptionsMetadata.java | 2 +- .../integration/x/kafka/KafkaZKOptionMixin.java | 2 +- .../integration/x/kafka/NamespaceDelegatingMetadataStore.java | 2 +- .../integration/x/kafka/WindowingOffsetManager.java | 2 +- .../xd/mail/JavaMailPropertiesFactoryBean.java | 2 +- .../main/java/org/springframework/xd/mail/MailProtocol.java | 2 +- .../java/org/springframework/xd/mail/MailServerMixin.java | 2 +- .../org/springframework/xd/mail/MailSinkOptionsMetadata.java | 2 +- .../springframework/xd/mail/MailSourceOptionsMetadata.java | 2 +- .../org/springframework/xd/mongodb/FieldSetConverter.java | 2 +- .../org/springframework/xd/mongodb/TupleWriteConverter.java | 2 +- .../extension/process/DelimitedStringToMapPropertyEditor.java | 2 +- .../xd/extension/process/ShellCommandProcessor.java | 2 +- .../xd/extension/process/ShellModuleOptionsMetadata.java | 2 +- .../xd/extension/process/ShellWordsParser.java | 2 +- .../xd/extension/process/PythonAvailableRule.java | 2 +- .../xd/extension/process/ShellCommandProcessorTests.java | 2 +- .../xd/extension/process/ShellWordsParserTest.java | 2 +- .../integration/reactor/config/ReactorNamespaceHandler.java | 2 +- .../reactor/config/SyslogInboundChannelAdapterParser.java | 2 +- .../reactor/net/ReactorNetSourceOptionsMetadata.java | 2 +- .../xd/integration/reactor/net/ReactorPeerFactoryBean.java | 2 +- .../reactor/net/ReactorPeerInboundChannelAdapter.java | 2 +- .../net/ReactorPeerInboundChannelAdapterConfiguration.java | 2 +- .../reactor/syslog/SyslogInboundChannelAdapter.java | 2 +- .../syslog/SyslogInboundChannelAdapterConfiguration.java | 2 +- .../NetServerInboundChannelAdapterIntegrationTests.java | 2 +- .../reactor/SyslogInboundChannelAdapterIntegrationTests.java | 2 +- .../xd/integration/reactor/TestMessageHandler.java | 2 +- .../org/springframework/xd/redis/RedisSinkConfiguration.java | 2 +- .../extension/script/ScriptModulePropertiesFactoryBean.java | 2 +- .../script/ScriptModulePropertiesFactoryBeanTest.java | 2 +- .../org/springframework/xd/spark/SparkAppOptionsMetadata.java | 2 +- .../main/java/org/springframework/xd/spark/package-info.java | 2 +- .../org/springframework/xd/spark/tasklet/SparkTasklet.java | 2 +- .../org/springframework/xd/spark/tasklet/package-info.java | 2 +- .../integration/x/splunk/SplunkTransformer.java | 2 +- .../springframework/xd/splunk/SplunkSinkOptionsMetadata.java | 2 +- .../springframework/xd/sqoop/SqoopEnvironmentProvider.java | 2 +- .../org/springframework/xd/sqoop/SqoopOptionsMetadata.java | 2 +- .../main/java/org/springframework/xd/sqoop/SqoopRunner.java | 2 +- .../main/java/org/springframework/xd/sqoop/SqoopTasklet.java | 2 +- .../main/java/org/springframework/xd/sqoop/package-info.java | 2 +- .../xd/syslog/SyslogSourceOptionsMetadata.java | 2 +- .../xd/syslog/SyslogTcpSourceOptionsMetadata.java | 2 +- .../xd/tcp/AbstractTcpConnectionFactoryOptionsMetadata.java | 2 +- .../tcp/ClientTcpConnectionFactoryOptionsMetadataMixin.java | 2 +- .../tcp/ServerTcpConnectionFactoryOptionsMetadataMixin.java | 2 +- .../xd/tcp/TcpClientSourceOptionsMetadata.java | 2 +- .../org/springframework/xd/tcp/TcpSinkOptionsMetadata.java | 2 +- .../org/springframework/xd/tcp/TcpSourceOptionsMetadata.java | 2 +- .../throughput/ThroughputSamplerMessageHandler.java | 2 +- .../throughput/ThroughputSamplerOptionsMetadata.java | 2 +- .../throughput/ThroughputSampleIntegrationTests.java | 2 +- .../src/test/resources/log4j.properties | 2 +- .../x/twitter/AbstractTwitterInboundChannelAdapter.java | 2 +- .../springframework/integration/x/twitter/TwitterMixin.java | 2 +- .../integration/x/twitter/TwitterSearchChannelAdapter.java | 2 +- .../integration/x/twitter/TwitterSearchOptionsMetadata.java | 2 +- .../integration/x/twitter/TwitterStreamChannelAdapter.java | 2 +- .../integration/x/twitter/TwitterStreamOptionsMetadata.java | 2 +- .../x/twitter/AbstractTwitterInboundChannelAdapterTests.java | 2 +- modules/common/shell-command-processor.xml | 2 +- .../processor/header-enricher/config/header-enricher.groovy | 2 +- modules/processor/shell/config/shell.xml | 2 +- modules/sink/shell/config/shell.xml | 2 +- modules/sink/throughput-sampler/config/throughput-sampler.xml | 2 +- modules/source/reactor-ip/config/reactor-ip.xml | 2 +- scripts/LICENSE | 4 ++-- .../xd/analytics/ml/AbstractFieldMappingAwareDataMapper.java | 2 +- .../java/org/springframework/xd/analytics/ml/Analytic.java | 2 +- .../java/org/springframework/xd/analytics/ml/InputMapper.java | 2 +- .../org/springframework/xd/analytics/ml/MappedAnalytic.java | 2 +- .../main/java/org/springframework/xd/analytics/ml/Mapper.java | 2 +- .../org/springframework/xd/analytics/ml/OutputMapper.java | 2 +- .../analytics/ml/AbstractFieldMappingAwareDataMapperTest.java | 2 +- .../org/springframework/xd/analytics/ml/DummyAnalytic.java | 2 +- .../org/springframework/xd/analytics/ml/DummyInputMapper.java | 2 +- .../springframework/xd/analytics/ml/DummyMappedAnalytic.java | 2 +- .../springframework/xd/analytics/ml/DummyOutputMapper.java | 2 +- .../springframework/xd/analytics/ml/MappedAnalyticTest.java | 2 +- .../xd/analytics/metrics/core/AggregateCount.java | 2 +- .../xd/analytics/metrics/core/AggregateCountResolution.java | 2 +- .../xd/analytics/metrics/core/AggregateCounterRepository.java | 2 +- .../springframework/xd/analytics/metrics/core/Counter.java | 2 +- .../xd/analytics/metrics/core/CounterRepository.java | 2 +- .../xd/analytics/metrics/core/FieldValueCounter.java | 2 +- .../analytics/metrics/core/FieldValueCounterRepository.java | 2 +- .../org/springframework/xd/analytics/metrics/core/Gauge.java | 2 +- .../xd/analytics/metrics/core/GaugeRepository.java | 2 +- .../org/springframework/xd/analytics/metrics/core/Metric.java | 2 +- .../xd/analytics/metrics/core/MetricRepository.java | 2 +- .../xd/analytics/metrics/core/MetricUtils.java | 2 +- .../springframework/xd/analytics/metrics/core/RichGauge.java | 2 +- .../xd/analytics/metrics/core/RichGaugeRepository.java | 2 +- .../analytics/metrics/integration/AbstractMetricHandler.java | 2 +- .../metrics/integration/AggregateCounterHandler.java | 2 +- .../metrics/integration/FieldValueCounterHandler.java | 2 +- .../xd/analytics/metrics/integration/GaugeHandler.java | 2 +- .../analytics/metrics/integration/MessageCounterHandler.java | 2 +- .../xd/analytics/metrics/integration/RichGaugeHandler.java | 2 +- .../xd/analytics/metrics/memory/InMemoryAggregateCounter.java | 2 +- .../metrics/memory/InMemoryAggregateCounterRepository.java | 2 +- .../analytics/metrics/memory/InMemoryCounterRepository.java | 2 +- .../metrics/memory/InMemoryFieldValueCounterRepository.java | 2 +- .../xd/analytics/metrics/memory/InMemoryGaugeRepository.java | 2 +- .../xd/analytics/metrics/memory/InMemoryMetricRepository.java | 2 +- .../analytics/metrics/memory/InMemoryRichGaugeRepository.java | 2 +- .../metrics/metadata/AggregateCounterSinkOptionsMetadata.java | 2 +- .../metadata/FieldValueCounterSinkOptionsMetadata.java | 2 +- .../xd/analytics/metrics/metadata/MetricNameMixin.java | 2 +- .../metrics/metadata/RichGaugeSinkOptionsMetadata.java | 2 +- .../metrics/redis/AbstractRedisMetricRepository.java | 2 +- .../xd/analytics/metrics/redis/AggregateKeyGenerator.java | 2 +- .../xd/analytics/metrics/redis/LoggingRecoveryCallback.java | 2 +- .../metrics/redis/RedisAggregateCounterRepository.java | 2 +- .../xd/analytics/metrics/redis/RedisCounterRepository.java | 2 +- .../metrics/redis/RedisFieldValueCounterRepository.java | 2 +- .../xd/analytics/metrics/redis/RedisGaugeRepository.java | 2 +- .../xd/analytics/metrics/redis/RedisRetryTemplate.java | 2 +- .../xd/analytics/metrics/redis/RedisRichGaugeRepository.java | 2 +- .../xd/analytics/metrics/redis/RedisUtils.java | 2 +- .../xd/analytics/metrics/redis/StringRedisRetryTemplate.java | 2 +- .../springframework/xd/store/AbstractInMemoryRepository.java | 2 +- .../org/springframework/xd/store/AbstractRedisRepository.java | 2 +- .../java/org/springframework/xd/store/AbstractRepository.java | 2 +- .../java/org/springframework/xd/store/DomainRepository.java | 2 +- .../org/springframework/xd/store/RangeCapableRepository.java | 2 +- .../xd/analytics/metrics/AbstractAggregateCounterTests.java | 2 +- .../xd/analytics/metrics/AbstractCounterRepositoryTests.java | 2 +- .../metrics/AbstractFieldValueCounterRepositoryTests.java | 2 +- .../analytics/metrics/AbstractRichGaugeRepositoryTests.java | 2 +- .../xd/analytics/metrics/SharedGaugeRepositoryTests.java | 2 +- .../xd/analytics/metrics/common/RedisRepositoriesConfig.java | 2 +- .../xd/analytics/metrics/core/CounterTests.java | 2 +- .../xd/analytics/metrics/core/FieldValueCounterTests.java | 2 +- .../springframework/xd/analytics/metrics/core/GaugeTests.java | 2 +- .../xd/analytics/metrics/core/MetricUtilsTests.java | 2 +- .../xd/analytics/metrics/core/RichGaugeTests.java | 2 +- .../analytics/metrics/integration/AggregateCounterTests.java | 2 +- .../metrics/integration/FieldValueCounterHandlerTests.java | 2 +- .../xd/analytics/metrics/integration/GaugeHandlerTests.java | 2 +- .../metrics/integration/MessageCounterHandlerTests.java | 2 +- .../analytics/metrics/integration/RichGaugeHandlerTests.java | 2 +- .../xd/analytics/metrics/integration/SimpleTweet.java | 2 +- .../metrics/memory/InMemoryAggregateCounterTests.java | 2 +- .../metrics/memory/InMemoryCounterRepositoryTests.java | 2 +- .../memory/InMemoryFieldValueCounterRepositoryTests.java | 2 +- .../metrics/memory/InMemoryGaugeRepositoryTests.java | 2 +- .../metrics/memory/InMemoryRichGaugeRepositoryTests.java | 2 +- .../analytics/metrics/redis/RedisAggregateCounterTests.java | 2 +- .../analytics/metrics/redis/RedisCounterRepositoryTests.java | 2 +- .../metrics/redis/RedisFieldValueCounterRepositoryTests.java | 2 +- .../xd/analytics/metrics/redis/RedisGaugeRepositoryTests.java | 2 +- .../xd/analytics/metrics/redis/RedisRetryTemplateTests.java | 2 +- .../metrics/redis/RedisRichGaugeRepositoryTests.java | 2 +- .../xd/store/AbstractInMemoryRepositoryTests.java | 2 +- .../xd/store/AbstractRedisRepositoryTests.java | 2 +- .../org/springframework/xd/store/BaseRepositoryTests.java | 2 +- .../springframework/xd/batch/XdBatchDatabaseInitializer.java | 2 +- .../xd/batch/hsqldb/server/HSQLServerBean.java | 2 +- .../xd/batch/hsqldb/server/HsqlDatasourceConfiguration.java | 2 +- .../xd/batch/hsqldb/server/HsqlServerApplication.java | 2 +- .../batch/item/jdbc/FieldSetSqlParameterSourceProvider.java | 2 +- .../dirt/integration/bus/MessageBusSupportBenchmarkTests.java | 2 +- .../xd/tuple/TupleCreationPerformanceTests.java | 2 +- .../xd/tuple/serializer/kryo/TupleCodecBenchmarkTests.java | 2 +- .../main/java/org/springframework/xd/dirt/DirtException.java | 2 +- .../xd/dirt/analytics/NoSuchMetricException.java | 2 +- .../springframework/xd/dirt/batch/RuntimeBatchConfigurer.java | 2 +- .../xd/dirt/batch/tasklet/JobLaunchingTasklet.java | 2 +- .../main/java/org/springframework/xd/dirt/cluster/Admin.java | 2 +- .../org/springframework/xd/dirt/cluster/AdminAttributes.java | 2 +- .../java/org/springframework/xd/dirt/cluster/Container.java | 2 +- .../springframework/xd/dirt/cluster/ContainerAttributes.java | 2 +- .../org/springframework/xd/dirt/cluster/ContainerFilter.java | 2 +- .../xd/dirt/cluster/ContainerShutdownException.java | 2 +- .../xd/dirt/cluster/ModuleMessageRateNotFoundException.java | 2 +- .../springframework/xd/dirt/cluster/NoContainerException.java | 2 +- .../xd/dirt/cluster/NoSuchContainerException.java | 2 +- .../xd/dirt/container/decryptor/DecryptorContext.java | 2 +- .../xd/dirt/container/decryptor/PropertiesDecryptor.java | 2 +- .../AbstractComponentScanningBeanDefinitionProvider.java | 2 +- .../initializer/AbstractResourceBeanDefinitionProvider.java | 2 +- .../dirt/container/initializer/OrderedContextInitializer.java | 2 +- .../PluginContextComponentScanningExtensionsInitializer.java | 2 +- .../PluginContextResourceExtensionsInitializer.java | 2 +- .../xd/dirt/container/initializer/PluginsInitializer.java | 2 +- .../xd/dirt/container/store/AdminRepository.java | 2 +- .../xd/dirt/container/store/ContainerRepository.java | 2 +- .../xd/dirt/container/store/DetailedContainer.java | 2 +- .../xd/dirt/container/store/ZooKeeperAdminRepository.java | 2 +- .../xd/dirt/container/store/ZooKeeperContainerRepository.java | 2 +- .../java/org/springframework/xd/dirt/core/BaseDefinition.java | 2 +- .../xd/dirt/core/DeploymentStatusRepository.java | 2 +- .../java/org/springframework/xd/dirt/core/DeploymentUnit.java | 2 +- .../springframework/xd/dirt/core/DeploymentUnitStatus.java | 2 +- .../src/main/java/org/springframework/xd/dirt/core/Job.java | 2 +- .../org/springframework/xd/dirt/core/JobDeploymentsPath.java | 2 +- .../xd/dirt/core/ModuleDeploymentRequestsPath.java | 2 +- .../springframework/xd/dirt/core/ModuleDeploymentsPath.java | 2 +- .../org/springframework/xd/dirt/core/ResourceDeployer.java | 2 +- .../org/springframework/xd/dirt/core/RuntimeIOException.java | 2 +- .../springframework/xd/dirt/core/RuntimeTimeoutException.java | 2 +- .../main/java/org/springframework/xd/dirt/core/Stream.java | 2 +- .../springframework/xd/dirt/core/StreamDeploymentsPath.java | 2 +- .../java/org/springframework/xd/dirt/event/AbstractEvent.java | 2 +- .../springframework/xd/dirt/event/AbstractModuleEvent.java | 2 +- .../springframework/xd/dirt/event/ModuleDeployedEvent.java | 2 +- .../springframework/xd/dirt/event/ModuleUndeployedEvent.java | 2 +- .../springframework/xd/dirt/integration/bus/BusCleaner.java | 2 +- .../dirt/integration/bus/MessageBusAwareChannelResolver.java | 2 +- .../bus/MessageBusAwareRouterBeanPostProcessor.java | 2 +- .../xd/dirt/integration/bus/StrictContentTypeResolver.java | 2 +- .../bus/converter/AbstractFromMessageConverter.java | 2 +- .../bus/converter/ByteArrayToStringMessageConverter.java | 2 +- .../bus/converter/CompositeMessageConverterFactory.java | 2 +- .../dirt/integration/bus/converter/ConversionException.java | 2 +- .../bus/converter/JavaToSerializedMessageConverter.java | 2 +- .../integration/bus/converter/JsonToPojoMessageConverter.java | 2 +- .../bus/converter/JsonToTupleMessageConverter.java | 2 +- .../dirt/integration/bus/converter/MessageConverterUtils.java | 2 +- .../integration/bus/converter/PojoToJsonMessageConverter.java | 2 +- .../bus/converter/PojoToStringMessageConverter.java | 2 +- .../bus/converter/SerializedToJavaMessageConverter.java | 2 +- .../bus/converter/StringToByteArrayMessageConverter.java | 2 +- .../bus/converter/TupleToJsonMessageConverter.java | 2 +- .../dirt/integration/bus/rabbit/NothingToDeleteException.java | 2 +- .../xd/dirt/integration/bus/rabbit/RabbitBusCleaner.java | 2 +- .../xd/dirt/integration/json/NewJsonPathUtils.java | 2 +- .../dirt/jdbc/util/DatabaseVendorFriendlyNameFactoryBean.java | 2 +- .../xd/dirt/job/BatchJobAlreadyExistsException.java | 2 +- .../java/org/springframework/xd/dirt/job/DetailedJobInfo.java | 2 +- .../java/org/springframework/xd/dirt/job/JobException.java | 2 +- .../xd/dirt/job/JobExecutionAlreadyRunningException.java | 2 +- .../org/springframework/xd/dirt/job/JobExecutionInfo.java | 2 +- .../xd/dirt/job/JobExecutionNotRunningException.java | 2 +- .../main/java/org/springframework/xd/dirt/job/JobFactory.java | 2 +- .../main/java/org/springframework/xd/dirt/job/JobInfo.java | 2 +- .../xd/dirt/job/JobInstanceAlreadyCompleteException.java | 2 +- .../java/org/springframework/xd/dirt/job/JobInstanceInfo.java | 2 +- .../xd/dirt/job/JobParametersInvalidException.java | 2 +- .../org/springframework/xd/dirt/job/JobRestartException.java | 2 +- .../springframework/xd/dirt/job/NoSuchBatchJobException.java | 2 +- .../xd/dirt/job/NoSuchBatchJobInstanceException.java | 2 +- .../xd/dirt/job/NoSuchJobExecutionException.java | 2 +- .../xd/dirt/job/NoSuchStepExecutionException.java | 2 +- .../org/springframework/xd/dirt/job/StepExecutionInfo.java | 2 +- .../xd/dirt/job/StepExecutionProgressInfo.java | 2 +- .../main/java/org/springframework/xd/dirt/job/StepType.java | 2 +- .../java/org/springframework/xd/dirt/job/TaskletType.java | 2 +- .../xd/dirt/job/dao/XdJdbcSearchableJobExecutionDao.java | 2 +- .../org/springframework/xd/dirt/job/dsl/ArgumentNode.java | 2 +- .../java/org/springframework/xd/dirt/job/dsl/AstNode.java | 2 +- .../xd/dirt/job/dsl/CheckpointedJobDefinitionException.java | 2 +- .../org/springframework/xd/dirt/job/dsl/ComposedJobUtil.java | 2 +- .../main/java/org/springframework/xd/dirt/job/dsl/Flow.java | 2 +- .../main/java/org/springframework/xd/dirt/job/dsl/Graph.java | 2 +- .../org/springframework/xd/dirt/job/dsl/JobDSLMessage.java | 2 +- .../org/springframework/xd/dirt/job/dsl/JobDefinition.java | 2 +- .../org/springframework/xd/dirt/job/dsl/JobDescriptor.java | 2 +- .../java/org/springframework/xd/dirt/job/dsl/JobNode.java | 2 +- .../java/org/springframework/xd/dirt/job/dsl/JobParser.java | 2 +- .../org/springframework/xd/dirt/job/dsl/JobReference.java | 2 +- .../java/org/springframework/xd/dirt/job/dsl/JobSeries.java | 2 +- .../org/springframework/xd/dirt/job/dsl/JobSpecification.java | 2 +- .../xd/dirt/job/dsl/JobSpecificationException.java | 2 +- .../xd/dirt/job/dsl/JobSpecificationVisitor.java | 2 +- .../main/java/org/springframework/xd/dirt/job/dsl/Link.java | 2 +- .../main/java/org/springframework/xd/dirt/job/dsl/Node.java | 2 +- .../main/java/org/springframework/xd/dirt/job/dsl/Split.java | 2 +- .../main/java/org/springframework/xd/dirt/job/dsl/Token.java | 2 +- .../java/org/springframework/xd/dirt/job/dsl/TokenKind.java | 2 +- .../java/org/springframework/xd/dirt/job/dsl/Tokenizer.java | 2 +- .../main/java/org/springframework/xd/dirt/job/dsl/Tokens.java | 2 +- .../java/org/springframework/xd/dirt/job/dsl/Transition.java | 2 +- .../xd/dirt/module/CustomModuleRegistryFactoryBean.java | 2 +- .../xd/dirt/module/DelegatingModuleRegistry.java | 2 +- .../springframework/xd/dirt/module/DependencyException.java | 2 +- .../org/springframework/xd/dirt/module/ExtendedResource.java | 2 +- .../org/springframework/xd/dirt/module/MD5StalenessCheck.java | 2 +- .../xd/dirt/module/ModuleAlreadyExistsException.java | 2 +- .../xd/dirt/module/ModuleDependencyRepository.java | 2 +- .../org/springframework/xd/dirt/module/ModuleDeployer.java | 2 +- .../org/springframework/xd/dirt/module/ModuleException.java | 2 +- .../xd/dirt/module/ModuleNotDeployedException.java | 2 +- .../org/springframework/xd/dirt/module/ModuleRegistry.java | 2 +- .../springframework/xd/dirt/module/NoSuchModuleException.java | 2 +- .../xd/dirt/module/ResourceDefinitionException.java | 2 +- .../xd/dirt/module/ResourceModuleRegistry.java | 2 +- .../org/springframework/xd/dirt/module/StalenessCheck.java | 2 +- .../xd/dirt/module/SynchronizingModuleRegistry.java | 2 +- .../xd/dirt/module/UploadedModuleDefinition.java | 2 +- .../xd/dirt/module/WritableModuleRegistry.java | 2 +- .../xd/dirt/module/WritableResourceModuleRegistry.java | 2 +- .../xd/dirt/module/jmx/ModuleObjectNamingStrategy.java | 2 +- .../springframework/xd/dirt/module/store/ModuleMetadata.java | 2 +- .../xd/dirt/module/store/ModuleMetadataRepository.java | 2 +- .../store/ZooKeeperComposedModuleDefinitionRegistry.java | 2 +- .../module/store/ZooKeeperModuleDependencyRepository.java | 2 +- .../dirt/module/store/ZooKeeperModuleMetadataRepository.java | 2 +- .../dirt/module/support/ModuleDefinitionRepositoryUtils.java | 2 +- .../xd/dirt/module/support/ModuleDefinitionService.java | 2 +- .../module/support/ThreadContextClassLoaderSetterAdvice.java | 2 +- .../metadata/AggregatorProcessorModuleOptionsMetadata.java | 2 +- .../xd/dirt/modules/metadata/FileAsRefMixin.java | 2 +- .../dirt/modules/metadata/FilePollHdfsJobOptionsMetadata.java | 2 +- .../xd/dirt/modules/metadata/FileReadingMode.java | 2 +- .../xd/dirt/modules/metadata/FileSinkOptionsMetadata.java | 2 +- .../xd/dirt/modules/metadata/FileSourceOptionsMetadata.java | 2 +- .../xd/dirt/modules/metadata/FtpHdfsJobOptionsMetadata.java | 2 +- .../xd/dirt/modules/metadata/FtpSinkOptionsMetadata.java | 2 +- .../xd/dirt/modules/metadata/FtpSourceOptionsMetadata.java | 2 +- .../dirt/modules/metadata/HdfsMongodbJobOptionsMetadata.java | 2 +- .../xd/dirt/modules/metadata/HttpSourceOptionsMetadata.java | 2 +- .../dirt/modules/metadata/JmsSourceModuleOptionsMetadata.java | 2 +- .../xd/dirt/modules/metadata/LogSinkOptionsMetadata.java | 2 +- .../xd/dirt/modules/metadata/MqttConnectionMixin.java | 2 +- .../xd/dirt/modules/metadata/MqttSinkOptionsMetadata.java | 2 +- .../xd/dirt/modules/metadata/MqttSourceOptionsMetadata.java | 2 +- .../xd/dirt/modules/metadata/RabbitConnectionMixin.java | 2 +- .../xd/dirt/modules/metadata/RabbitSinkOptionsMetadata.java | 2 +- .../xd/dirt/modules/metadata/RabbitSourceOptionsMetadata.java | 2 +- .../xd/dirt/modules/metadata/RedisConnectionMixin.java | 2 +- .../xd/dirt/modules/metadata/RedisSinkOptionsMetadata.java | 2 +- .../xd/dirt/modules/metadata/SftpSourceOptionsMetadata.java | 2 +- .../modules/metadata/SplitterProcessorOptionsMetadata.java | 2 +- .../xd/dirt/modules/metadata/TailSourceOptionsMetadata.java | 2 +- .../xd/dirt/modules/metadata/TimeSourceOptionsMetadata.java | 2 +- .../modules/metadata/TimestampFileJobOptionsMetadata.java | 2 +- .../dirt/modules/metadata/TriggerSourceOptionsMetadata.java | 2 +- .../springframework/xd/dirt/plugins/AbstractJobPlugin.java | 2 +- .../xd/dirt/plugins/AbstractMessageBusBinderPlugin.java | 2 +- .../org/springframework/xd/dirt/plugins/AbstractPlugin.java | 2 +- .../springframework/xd/dirt/plugins/AbstractStreamPlugin.java | 2 +- .../springframework/xd/dirt/plugins/ContainerInfoPlugin.java | 2 +- .../springframework/xd/dirt/plugins/MBeanExportingPlugin.java | 2 +- .../xd/dirt/plugins/ModuleConfigurationException.java | 2 +- .../org/springframework/xd/dirt/plugins/ModuleInfoPlugin.java | 2 +- .../xd/dirt/plugins/PropertiesDecryptorPlugin.java | 2 +- .../xd/dirt/plugins/ZookeeperConnectionPlugin.java | 2 +- .../plugins/job/BatchJobAlreadyExistsInRegistryException.java | 2 +- .../springframework/xd/dirt/plugins/job/BatchJobHeaders.java | 2 +- .../dirt/plugins/job/BatchJobRegistryBeanPostProcessor.java | 2 +- .../xd/dirt/plugins/job/DistributedJobLocator.java | 2 +- .../xd/dirt/plugins/job/DistributedJobService.java | 2 +- .../xd/dirt/plugins/job/ExpandedJobParametersConverter.java | 2 +- .../xd/dirt/plugins/job/JobEventsListenerPlugin.java | 2 +- .../xd/dirt/plugins/job/JobLaunchRequestTransformer.java | 2 +- .../xd/dirt/plugins/job/JobParametersBean.java | 2 +- .../xd/dirt/plugins/job/JobPartitionerPlugin.java | 2 +- .../org/springframework/xd/dirt/plugins/job/JobPlugin.java | 2 +- .../xd/dirt/plugins/job/JobPluginMetadataResolver.java | 2 +- .../xd/dirt/plugins/job/ModuleJobLauncher.java | 2 +- .../plugins/job/support/ExecutionContextJacksonMixIn.java | 2 +- .../dirt/plugins/job/support/JobLaunchingJobRepository.java | 2 +- .../job/support/JobLaunchingJobRepositoryFactoryBean.java | 2 +- .../dirt/plugins/job/support/StepExecutionJacksonMixIn.java | 2 +- .../dirt/plugins/job/support/listener/BatchJobListener.java | 2 +- .../plugins/job/support/listener/BatchListenerEventType.java | 2 +- .../dirt/plugins/job/support/listener/ChunkContextInfo.java | 2 +- .../support/listener/FileDeletionStepExecutionListener.java | 2 +- .../plugins/job/support/listener/SimpleXdChunkListener.java | 2 +- .../plugins/job/support/listener/SimpleXdItemListener.java | 2 +- .../job/support/listener/SimpleXdJobExecutionListener.java | 2 +- .../plugins/job/support/listener/SimpleXdSkipListener.java | 2 +- .../job/support/listener/SimpleXdStepExecutionListener.java | 2 +- .../plugins/job/support/listener/XDJobListenerConstants.java | 2 +- .../dirt/plugins/spark/streaming/LocalMessageBusHolder.java | 2 +- .../dirt/plugins/spark/streaming/MessageBusConfiguration.java | 2 +- .../xd/dirt/plugins/spark/streaming/MessageBusReceiver.java | 2 +- .../xd/dirt/plugins/spark/streaming/MessageBusSender.java | 2 +- .../dirt/plugins/spark/streaming/SparkStreamingChannel.java | 2 +- .../xd/dirt/plugins/spark/streaming/SparkStreamingPlugin.java | 2 +- .../xd/dirt/plugins/stream/CustomMimeTypeConverter.java | 2 +- .../xd/dirt/plugins/stream/ModuleTypeConversionPlugin.java | 2 +- .../stream/ModuleTypeConversionPluginMetadataResolver.java | 2 +- .../xd/dirt/plugins/stream/ModuleTypeConversionSupport.java | 2 +- .../springframework/xd/dirt/plugins/stream/StreamPlugin.java | 2 +- .../xd/dirt/rest/AbstractBatchJobsController.java | 2 +- .../xd/dirt/rest/AccessControlInterceptor.java | 2 +- .../org/springframework/xd/dirt/rest/AdminController.java | 2 +- .../xd/dirt/rest/BatchJobExecutionsController.java | 2 +- .../xd/dirt/rest/BatchJobInstancesController.java | 2 +- .../org/springframework/xd/dirt/rest/BatchJobsController.java | 2 +- .../xd/dirt/rest/BatchStepExecutionsController.java | 2 +- .../springframework/xd/dirt/rest/CompletionsController.java | 2 +- .../springframework/xd/dirt/rest/ContainersController.java | 2 +- .../xd/dirt/rest/DetailedJobInfoResourceAssembler.java | 2 +- .../dirt/rest/DetailedModuleDefinitionResourceAssembler.java | 2 +- .../xd/dirt/rest/DocumentParseResultResourceAssembler.java | 2 +- .../xd/dirt/rest/JobDefinitionResourceAssembler.java | 2 +- .../xd/dirt/rest/JobExecutionInfoResourceAssembler.java | 2 +- .../xd/dirt/rest/JobInfoResourceAssembler.java | 2 +- .../xd/dirt/rest/JobInstanceInfoResourceAssembler.java | 2 +- .../java/org/springframework/xd/dirt/rest/JobsController.java | 2 +- .../xd/dirt/rest/ModuleDefinitionResourceAssembler.java | 2 +- .../xd/dirt/rest/ModuleMetadataResourceAssembler.java | 2 +- .../org/springframework/xd/dirt/rest/ModulesController.java | 2 +- .../xd/dirt/rest/ModulesMetadataController.java | 2 +- .../java/org/springframework/xd/dirt/rest/PasswordUtils.java | 2 +- .../org/springframework/xd/dirt/rest/RestConfiguration.java | 2 +- .../springframework/xd/dirt/rest/RestControllerAdvice.java | 2 +- .../xd/dirt/rest/RuntimeContainerResourceAssembler.java | 2 +- .../xd/dirt/rest/StepExecutionInfoResourceAssembler.java | 2 +- .../dirt/rest/StepExecutionProgressInfoResourceAssembler.java | 2 +- .../xd/dirt/rest/StreamDefinitionResourceAssembler.java | 2 +- .../org/springframework/xd/dirt/rest/StreamsController.java | 2 +- .../org/springframework/xd/dirt/rest/ToolsController.java | 2 +- .../java/org/springframework/xd/dirt/rest/XDController.java | 2 +- .../org/springframework/xd/dirt/rest/XdErrorController.java | 2 +- .../springframework/xd/dirt/rest/meta/VersionController.java | 2 +- .../xd/dirt/rest/metrics/AbstractMetricsController.java | 2 +- .../xd/dirt/rest/metrics/AggregateCountersController.java | 2 +- .../xd/dirt/rest/metrics/CountersController.java | 2 +- .../rest/metrics/DeepAggregateCountResourceAssembler.java | 2 +- .../xd/dirt/rest/metrics/DeepCounterResourceAssembler.java | 2 +- .../rest/metrics/DeepFieldValueCounterResourceAssembler.java | 2 +- .../xd/dirt/rest/metrics/DeepGaugeResourceAssembler.java | 2 +- .../xd/dirt/rest/metrics/DeepRichGaugeResourceAssembler.java | 2 +- .../xd/dirt/rest/metrics/FieldValueCountersController.java | 2 +- .../xd/dirt/rest/metrics/GaugesController.java | 2 +- .../xd/dirt/rest/metrics/RichGaugesController.java | 2 +- .../xd/dirt/rest/metrics/ShallowMetricResourceAssembler.java | 2 +- .../xd/dirt/rest/security/SecurityController.java | 2 +- .../xd/dirt/rest/validation/ValidationController.java | 2 +- .../org/springframework/xd/dirt/server/ApplicationUtils.java | 2 +- .../xd/dirt/server/MessageBusClassLoaderFactory.java | 2 +- .../xd/dirt/server/MessageBusExtensionsConfiguration.java | 2 +- .../springframework/xd/dirt/server/ParentConfiguration.java | 2 +- .../xd/dirt/server/SharedServerContextConfiguration.java | 2 +- .../xd/dirt/server/admin/AdminPortNotAvailableException.java | 2 +- .../xd/dirt/server/admin/AdminServerApplication.java | 2 +- .../xd/dirt/server/admin/deployment/ContainerMatcher.java | 2 +- .../deployment/DefaultDeploymentUnitStateCalculator.java | 2 +- .../xd/dirt/server/admin/deployment/DeploymentAction.java | 2 +- .../xd/dirt/server/admin/deployment/DeploymentException.java | 2 +- .../xd/dirt/server/admin/deployment/DeploymentHandler.java | 2 +- .../xd/dirt/server/admin/deployment/DeploymentMessage.java | 2 +- .../server/admin/deployment/DeploymentMessagePublisher.java | 2 +- .../admin/deployment/DeploymentUnitStateCalculator.java | 2 +- .../xd/dirt/server/admin/deployment/DeploymentUnitType.java | 2 +- .../admin/deployment/ModuleDeploymentPropertiesProvider.java | 2 +- .../dirt/server/admin/deployment/ModuleDeploymentStatus.java | 2 +- .../deployment/RuntimeModuleDeploymentPropertiesProvider.java | 2 +- .../admin/deployment/StreamRuntimePropertiesProvider.java | 2 +- .../xd/dirt/server/admin/deployment/zk/ContainerListener.java | 2 +- .../deployment/zk/ContainerMatchingModuleRedeployer.java | 2 +- .../deployment/zk/DefaultDeploymentStateRecalculator.java | 2 +- .../zk/DefaultModuleDeploymentPropertiesProvider.java | 2 +- .../deployment/zk/DepartedContainerModuleRedeployer.java | 2 +- .../server/admin/deployment/zk/DeploymentConfiguration.java | 2 +- .../xd/dirt/server/admin/deployment/zk/DeploymentLoader.java | 2 +- .../server/admin/deployment/zk/DeploymentMessageConsumer.java | 2 +- .../xd/dirt/server/admin/deployment/zk/DeploymentQueue.java | 2 +- .../dirt/server/admin/deployment/zk/DeploymentSupervisor.java | 2 +- .../server/admin/deployment/zk/ModuleDeploymentWriter.java | 2 +- .../xd/dirt/server/admin/deployment/zk/ModuleRedeployer.java | 2 +- .../server/admin/deployment/zk/SupervisorElectedEvent.java | 2 +- .../admin/deployment/zk/SupervisorElectionListener.java | 2 +- .../dirt/server/admin/deployment/zk/ZKDeploymentHandler.java | 2 +- .../admin/deployment/zk/ZKDeploymentMessagePublisher.java | 2 +- .../server/admin/deployment/zk/ZKJobDeploymentHandler.java | 2 +- .../server/admin/deployment/zk/ZKStreamDeploymentHandler.java | 2 +- .../server/container/ContainerBootstrapConfiguration.java | 2 +- .../xd/dirt/server/container/ContainerBootstrapContext.java | 2 +- .../xd/dirt/server/container/ContainerConfiguration.java | 2 +- .../xd/dirt/server/container/ContainerRegistrar.java | 2 +- .../xd/dirt/server/container/ContainerServerApplication.java | 2 +- .../xd/dirt/server/container/DeploymentListener.java | 2 +- .../springframework/xd/dirt/server/options/AdminOptions.java | 2 +- .../xd/dirt/server/options/BeanPropertiesPropertySource.java | 2 +- .../options/CommandLinePropertySourceOverridingListener.java | 2 +- .../xd/dirt/server/options/CommonDistributedOptions.java | 2 +- .../springframework/xd/dirt/server/options/CommonOptions.java | 2 +- .../xd/dirt/server/options/ContainerOptions.java | 2 +- .../server/options/ResourcePatternScanningOptionHandler.java | 2 +- .../server/options/ResourcePatternScanningOptionHandlers.java | 2 +- .../xd/dirt/server/options/SingleNodeOptions.java | 2 +- .../dirt/server/security/FileAuthenticationConfiguration.java | 2 +- .../dirt/server/security/LdapAuthenticationConfiguration.java | 2 +- .../xd/dirt/server/singlenode/SingleNodeApplication.java | 2 +- .../xd/dirt/spark/SparkStreamingContainerFilter.java | 2 +- .../org/springframework/xd/dirt/stream/AbstractDeployer.java | 2 +- .../xd/dirt/stream/AbstractInstancePersistingDeployer.java | 2 +- .../xd/dirt/stream/AlreadyDeployedException.java | 2 +- .../java/org/springframework/xd/dirt/stream/BaseInstance.java | 2 +- .../xd/dirt/stream/DefinitionAlreadyExistsException.java | 2 +- .../springframework/xd/dirt/stream/DeploymentValidator.java | 2 +- .../springframework/xd/dirt/stream/DocumentParseResult.java | 2 +- .../src/main/java/org/springframework/xd/dirt/stream/Job.java | 2 +- .../org/springframework/xd/dirt/stream/JobDefinition.java | 2 +- .../xd/dirt/stream/JobDefinitionRepository.java | 2 +- .../java/org/springframework/xd/dirt/stream/JobDeployer.java | 2 +- .../org/springframework/xd/dirt/stream/JobRepository.java | 2 +- .../xd/dirt/stream/NoSuchDefinitionException.java | 2 +- .../springframework/xd/dirt/stream/NotDeployedException.java | 2 +- .../org/springframework/xd/dirt/stream/ParsingContext.java | 2 +- .../main/java/org/springframework/xd/dirt/stream/Stream.java | 2 +- .../org/springframework/xd/dirt/stream/StreamDefinition.java | 2 +- .../xd/dirt/stream/StreamDefinitionRepository.java | 2 +- .../xd/dirt/stream/StreamDefinitionRepositoryUtils.java | 2 +- .../org/springframework/xd/dirt/stream/StreamDeployer.java | 2 +- .../org/springframework/xd/dirt/stream/StreamException.java | 2 +- .../org/springframework/xd/dirt/stream/StreamFactory.java | 2 +- .../org/springframework/xd/dirt/stream/StreamRepository.java | 2 +- .../java/org/springframework/xd/dirt/stream/XDParser.java | 2 +- .../org/springframework/xd/dirt/stream/XDStreamParser.java | 2 +- .../stream/completion/AddModuleOptionsExpansionStrategy.java | 2 +- .../dirt/stream/completion/CompletionExpansionStrategy.java | 2 +- .../xd/dirt/stream/completion/CompletionProvider.java | 2 +- .../xd/dirt/stream/completion/CompletionRecoveryStrategy.java | 2 +- .../completion/EmptyStartYieldsModulesRecoveryStrategy.java | 2 +- .../completion/ExpandOneDashToTwoDashesRecoveryStrategy.java | 2 +- .../stream/completion/ModulesAfterPipeRecoveryStrategy.java | 2 +- .../completion/OptionNameAfterDashDashRecoveryStrategy.java | 2 +- .../completion/PipeIntoOtherModulesExpansionStrategy.java | 2 +- .../StacktraceFingerprintingCompletionRecoveryStrategy.java | 2 +- .../completion/UnfinishedModuleNameRecoveryStrategy.java | 2 +- .../completion/UnfinishedOptionNameRecoveryStrategy.java | 2 +- .../org/springframework/xd/dirt/stream/dsl/ArgumentNode.java | 2 +- .../java/org/springframework/xd/dirt/stream/dsl/AstNode.java | 2 +- .../org/springframework/xd/dirt/stream/dsl/ChannelNode.java | 2 +- .../org/springframework/xd/dirt/stream/dsl/ChannelType.java | 2 +- .../stream/dsl/CheckpointedStreamDefinitionException.java | 2 +- .../org/springframework/xd/dirt/stream/dsl/LabelNode.java | 2 +- .../org/springframework/xd/dirt/stream/dsl/ModuleNode.java | 2 +- .../springframework/xd/dirt/stream/dsl/SinkChannelNode.java | 2 +- .../springframework/xd/dirt/stream/dsl/SourceChannelNode.java | 2 +- .../xd/dirt/stream/dsl/StreamConfigParser.java | 2 +- .../xd/dirt/stream/dsl/StreamDefinitionException.java | 2 +- .../xd/dirt/stream/dsl/StreamLookupEnvironment.java | 2 +- .../org/springframework/xd/dirt/stream/dsl/StreamNode.java | 2 +- .../java/org/springframework/xd/dirt/stream/dsl/Token.java | 2 +- .../org/springframework/xd/dirt/stream/dsl/TokenKind.java | 2 +- .../org/springframework/xd/dirt/stream/dsl/Tokenizer.java | 2 +- .../org/springframework/xd/dirt/stream/dsl/XDDSLMessages.java | 2 +- .../dirt/stream/zookeeper/RepositoryConnectionListener.java | 2 +- .../stream/zookeeper/ZooKeeperJobDefinitionRepository.java | 2 +- .../xd/dirt/stream/zookeeper/ZooKeeperJobRepository.java | 2 +- .../stream/zookeeper/ZooKeeperStreamDefinitionRepository.java | 2 +- .../xd/dirt/stream/zookeeper/ZooKeeperStreamRepository.java | 2 +- .../xd/dirt/test/AbstractSingleNodeNamedChannelModule.java | 2 +- .../test/AbstractSingleNodeNamedChannelModuleFactory.java | 2 +- .../org/springframework/xd/dirt/test/NamedChannelModule.java | 2 +- .../springframework/xd/dirt/test/ResourceStateVerifier.java | 2 +- .../xd/dirt/test/SingleNodeIntegrationTestSupport.java | 2 +- .../springframework/xd/dirt/test/SingletonModuleRegistry.java | 2 +- .../dirt/test/process/AbstractSingleNodeProcessingChain.java | 2 +- .../xd/dirt/test/process/SingleNodeProcessingChain.java | 2 +- .../dirt/test/process/SingleNodeProcessingChainConsumer.java | 2 +- .../dirt/test/process/SingleNodeProcessingChainProducer.java | 2 +- .../dirt/test/process/SingleNodeProcessingChainSupport.java | 2 +- .../xd/dirt/test/sink/AbstractSingleNodeNamedChannelSink.java | 2 +- .../springframework/xd/dirt/test/sink/NamedChannelSink.java | 2 +- .../xd/dirt/test/sink/SingleNodeNamedChannelSinkFactory.java | 2 +- .../xd/dirt/test/sink/SingleNodeNamedQueueSink.java | 2 +- .../xd/dirt/test/sink/SingleNodeNamedTopicSink.java | 2 +- .../test/source/AbstractSingleNodeNamedChannelSource.java | 2 +- .../xd/dirt/test/source/NamedChannelSource.java | 2 +- .../dirt/test/source/SingleNodeNamedChannelSourceFactory.java | 2 +- .../xd/dirt/test/source/SingleNodeNamedQueueSource.java | 2 +- .../xd/dirt/test/source/SingleNodeNamedTopicSource.java | 2 +- .../java/org/springframework/xd/dirt/util/BannerUtils.java | 2 +- .../org/springframework/xd/dirt/util/ConfigLocations.java | 2 +- .../xd/dirt/util/DeploymentPropertiesUtility.java | 2 +- .../springframework/xd/dirt/util/PageNotFoundException.java | 2 +- .../java/org/springframework/xd/dirt/util/PagingUtility.java | 2 +- .../java/org/springframework/xd/dirt/util/RuntimeUtils.java | 2 +- .../xd/dirt/util/XdConfigLoggingInitializer.java | 2 +- .../java/org/springframework/xd/dirt/util/XdProfiles.java | 2 +- .../main/java/org/springframework/xd/dirt/util/XdUtils.java | 2 +- .../xd/dirt/util/logging/CustomLoggerConverter.java | 2 +- .../xd/dirt/util/logging/LoggerAbbreviator.java | 2 +- .../xd/dirt/util/logging/VersionPatternConverter.java | 2 +- .../xd/dirt/util/logging/VersionPatternLayout.java | 2 +- .../xd/dirt/util/logging/VersionPatternParser.java | 2 +- .../springframework/xd/dirt/zookeeper/ChildPathIterator.java | 2 +- .../springframework/xd/dirt/zookeeper/EmbeddedZooKeeper.java | 2 +- .../java/org/springframework/xd/dirt/zookeeper/Paths.java | 2 +- .../xd/dirt/zookeeper/ZooKeeperAccessException.java | 2 +- .../xd/dirt/zookeeper/ZooKeeperConnection.java | 2 +- .../xd/dirt/zookeeper/ZooKeeperConnectionConfigurer.java | 2 +- .../xd/dirt/zookeeper/ZooKeeperConnectionListener.java | 2 +- .../org/springframework/xd/dirt/zookeeper/ZooKeeperUtils.java | 2 +- .../test/java/org/springframework/xd/dirt/AdhocTestSuite.java | 2 +- .../xd/dirt/batch/RuntimeBatchConfigurerIntegrationTests.java | 2 +- .../xd/dirt/batch/RuntimeBatchConfigurerTests.java | 2 +- .../xd/dirt/batch/tasklet/JobLaunchingTaskletTests.java | 2 +- .../xd/dirt/config/AbstractSingleNodeInitializationTests.java | 2 +- .../xd/dirt/config/LocalSingleNodeInitializationTests.java | 2 +- .../xd/dirt/config/RabbitSingleNodeInitializationTests.java | 2 +- .../xd/dirt/config/RedisSingleNodeInitializationTests.java | 2 +- .../xd/dirt/config/TestMessageBusInjection.java | 2 +- .../xd/dirt/config/ZooKeeperConnectionConfiguration.java | 2 +- .../xd/dirt/config/ZookeeperClientConnectTests.java | 2 +- .../dirt/container/store/ZooKeeperAdminRepositoryTests.java | 2 +- .../xd/dirt/core/ModuleDeploymentsPathTest.java | 2 +- .../xd/dirt/core/StreamDeploymentsPathTest.java | 2 +- .../xd/dirt/integration/bus/AbstractMessageBusTests.java | 2 +- .../xd/dirt/integration/bus/AbstractTestMessageBus.java | 2 +- .../xd/dirt/integration/bus/BrokerBusTests.java | 2 +- .../integration/bus/MessageBusAwareChannelResolverTests.java | 2 +- .../xd/dirt/integration/bus/MessageBusSupportTests.java | 2 +- .../xd/dirt/integration/bus/PartitionCapableBusTests.java | 2 +- .../xd/dirt/integration/bus/PartitionTestSupport.java | 2 +- .../integration/bus/converter/FromMessageConverterTests.java | 2 +- .../xd/dirt/integration/bus/kafka/KafkaMessageBusTests.java | 2 +- .../xd/dirt/integration/bus/kafka/KafkaTestMessageBus.java | 2 +- .../integration/bus/kafka/RawKafkaPartitionTestSupport.java | 2 +- .../integration/bus/kafka/RawModeKafkaMessageBusTests.java | 2 +- .../xd/dirt/integration/bus/local/LocalMessageBusTests.java | 2 +- .../xd/dirt/integration/bus/rabbit/RabbitBusCleanerTests.java | 2 +- .../xd/dirt/integration/bus/rabbit/RabbitMessageBusTests.java | 2 +- .../xd/dirt/integration/bus/rabbit/RabbitTestMessageBus.java | 2 +- .../xd/dirt/integration/bus/redis/RedisMessageBusTests.java | 2 +- .../xd/dirt/integration/bus/redis/RedisTestMessageBus.java | 2 +- .../xd/dirt/integration/kafka/TestKafkaCluster.java | 2 +- .../dirt/integration/redis/AbstractRedisSerializerTests.java | 2 +- .../integration/redis/RedisPublishingMessageHandlerTests.java | 2 +- .../redis/RedisQueueInboundChannelAdapterTests.java | 2 +- .../redis/RedisQueueOutboundChannelAdapterTests.java | 2 +- .../org/springframework/xd/dirt/jms/AmqBrokerAndTest.java | 2 +- .../springframework/xd/dirt/job/StepExecutionInfoTests.java | 2 +- .../org/springframework/xd/dirt/job/dsl/JobParserTests.java | 2 +- .../xd/dirt/listener/ZooKeeperContainerRepositoryTests.java | 2 +- .../springframework/xd/dirt/module/CompositeModuleTests.java | 2 +- .../xd/dirt/module/DelegatingModuleRegistryTests.java | 2 +- .../xd/dirt/module/ModuleDefinitionMatchers.java | 2 +- .../xd/dirt/module/ResourceModuleRegistryTests.java | 2 +- .../xd/dirt/module/SingletonModuleRegistryTests.java | 2 +- .../xd/dirt/module/SynchronizingModuleRegistryTests.java | 2 +- .../xd/dirt/module/TestModuleEventListener.java | 2 +- .../dirt/module/WritableResourceModuleRegistryLogicTests.java | 2 +- .../xd/dirt/module/jmx/ModuleObjectNamingStrategyTests.java | 2 +- .../xd/dirt/modules/metadata/InputTypeTests.java | 2 +- .../modules/metadata/ModuleOptionsMetadataSanityTests.java | 2 +- .../modules/metadata/TestTupleProcessorOptionsMetadata.java | 2 +- .../xd/dirt/plugins/ModuleDeploymentTests.java | 2 +- .../dirt/plugins/job/ExpandedJobParametersConverterTests.java | 2 +- .../xd/dirt/plugins/job/JobLaunchRequestTransformerTests.java | 2 +- .../xd/dirt/plugins/job/JobParametersBeanTests.java | 2 +- .../springframework/xd/dirt/plugins/job/JobPluginTests.java | 2 +- .../org/springframework/xd/dirt/plugins/job/JobRepoTests.java | 2 +- .../xd/dirt/plugins/job/RabbitJobPluginTests.java | 2 +- .../xd/dirt/plugins/job/RedisJobPluginTests.java | 2 +- .../plugins/job/support/JobLaunchingJobRepositoryTests.java | 2 +- .../xd/dirt/plugins/job/support/JobSupport.java | 2 +- .../plugins/job/support/StepExecutionJacksonMixInTests.java | 2 +- .../xd/dirt/plugins/job/support/StepSupport.java | 2 +- .../xd/dirt/plugins/stream/MessageBusRegistrationTests.java | 2 +- .../xd/dirt/plugins/stream/StreamPluginTests.java | 2 +- .../xd/dirt/rest/AbstractControllerIntegrationTest.java | 2 +- .../rest/BatchJobExecutionsControllerIntegrationTests.java | 2 +- .../rest/BatchJobInstancesControllerIntegrationTests.java | 2 +- .../xd/dirt/rest/BatchJobsControllerIntegrationTests.java | 2 +- .../rest/BatchStepExecutionsControllerIntegrationTests.java | 2 +- .../xd/dirt/rest/ContainersControllerIntegrationTests.java | 2 +- .../java/org/springframework/xd/dirt/rest/Dependencies.java | 2 +- .../xd/dirt/rest/JobsControllerIntegrationTests.java | 2 +- .../xd/dirt/rest/JobsControllerIntegrationTestsConfig.java | 2 +- .../dirt/rest/ModuleMetadataControllerIntegrationTests.java | 2 +- .../xd/dirt/rest/ModulesControllerIntegrationTests.java | 2 +- .../org/springframework/xd/dirt/rest/PasswordUtilsTests.java | 2 +- .../rest/StreamsControllerIntegrationWithRepositoryTests.java | 2 +- ...StreamsControllerIntegrationWithRepositoryTestsConfig.java | 2 +- .../xd/dirt/rest/meta/VersionControllerIntegrationTests.java | 2 +- .../metrics/AggregateCountersControllerIntegrationTests.java | 2 +- .../dirt/rest/metrics/CountersControllerIntegrationTests.java | 2 +- .../metrics/FieldValueCountersControllerIntegrationTests.java | 2 +- .../xd/dirt/rest/metrics/GaugeControllerIntegrationTests.java | 2 +- .../rest/metrics/RichGaugeControllerIntegrationTests.java | 2 +- .../rest/security/SecurityControllerIntegrationTests.java | 2 +- .../SecurityControllerIntegrationTestsInitializer.java | 2 +- .../rest/validation/ValidationControllerIntegrationTests.java | 2 +- .../springframework/xd/dirt/security/LdapServerResource.java | 2 +- .../springframework/xd/dirt/security/SecurityTestUtils.java | 2 +- .../SingleNodeApplicationWithDefaultSecurityTest.java | 2 +- .../SingleNodeApplicationWithLdapSearchAndBindTest.java | 2 +- .../security/SingleNodeApplicationWithLdapSimpleBindTest.java | 2 +- .../xd/dirt/security/SingleNodeApplicationWithSslTest.java | 2 +- .../SingleNodeApplicationWithUserBasedSecurityTest.java | 2 +- .../dirt/security/SingleNodeApplicationWithUsersFileTest.java | 2 +- .../springframework/xd/dirt/security/SpringXdResource.java | 2 +- .../xd/dirt/security/support/UserCredentials.java | 2 +- .../xd/dirt/server/ContainerServerApplicationTests.java | 2 +- .../xd/dirt/server/TestApplicationBootstrap.java | 2 +- .../server/admin/deployment/DefaultContainerMatcherTests.java | 2 +- ...edTransportSingleNodeStreamDeploymentIntegrationTests.java | 2 +- .../AbstractSingleNodeStreamDeploymentIntegrationTests.java | 2 +- .../xd/dirt/stream/ComposedModuleStreamTests.java | 2 +- .../org/springframework/xd/dirt/stream/DeployerTests.java | 2 +- .../xd/dirt/stream/DeploymentPropertiesParserTests.java | 2 +- .../xd/dirt/stream/ExampleProcessingChainTests.java | 2 +- .../springframework/xd/dirt/stream/FileSourceModuleTests.java | 2 +- .../KafkaSingleNodeStreamDeploymentIntegrationTests.java | 2 +- .../LocalSingleNodeStreamDeploymentIntegrationTests.java | 2 +- .../xd/dirt/stream/ModuleOptionsDefaultsOrderingTests.java | 2 +- .../RabbitSingleNodeStreamDeploymentIntegrationTests.java | 2 +- .../RedisSingleNodeStreamDeploymentIntegrationTests.java | 2 +- .../org/springframework/xd/dirt/stream/StreamTestSupport.java | 2 +- .../xd/dirt/stream/TypeConvertingStreamTests.java | 2 +- .../springframework/xd/dirt/stream/XDStreamParserTests.java | 2 +- .../dirt/stream/completionnoscan/CompletionProviderTests.java | 2 +- .../xd/dirt/stream/dsl/StreamConfigParserTests.java | 2 +- .../springframework/xd/dirt/stream/dsl/TokenizerTests.java | 2 +- .../zookeeper/ZooKeeperStreamDefinitionRepositoryTests.java | 2 +- .../org/springframework/xd/dirt/util/PagingUtilityTests.java | 2 +- .../org/springframework/xd/extensions/ExtensionsTests.java | 2 +- .../xd/extensions/PropertiesDecryptorTests.java | 2 +- .../test/java/org/springframework/xd/extensions/test/Bar.java | 2 +- .../test/java/org/springframework/xd/extensions/test/Foo.java | 2 +- .../org/springframework/xd/extensions/test/MyXDBeans.java | 2 +- .../xd/extensions/test/StubPojoToStringConverter.java | 2 +- .../java/spring/xd/bus/ext/CustomKryoRegistrarConfig.java | 2 +- .../src/test/java/spring/xd/ext/encryption/MyDecryptor.java | 2 +- spring-xd-dirt/src/test/resources/logback.groovy | 2 +- .../xd/distributed/util/DefaultDistributedTestSupport.java | 2 +- .../xd/distributed/util/DistributedTestSupport.java | 2 +- .../xd/distributed/util/ServerProcessUtils.java | 2 +- .../xd/distributed/test/AbstractDistributedTests.java | 2 +- .../xd/distributed/test/ContainerRedeploymentTests.java | 2 +- .../xd/distributed/test/DistributedTestSuite.java | 2 +- .../springframework/xd/distributed/test/JobStateTests.java | 2 +- .../xd/distributed/test/StreamDeploymentTests.java | 2 +- .../xd/distributed/test/StreamPartitionTests.java | 2 +- .../springframework/xd/distributed/test/StreamStateTests.java | 2 +- .../org/springframework/xd/gemfire/server/CacheServer.java | 2 +- .../xd/gemfire/server/LoggingCacheListener.java | 2 +- .../org/springframework/xd/gradle/plugin/ModulePlugin.groovy | 2 +- .../xd/batch/item/hadoop/AbstractHdfsItemWriter.java | 2 +- .../xd/batch/item/hadoop/HdfsTextItemWriter.java | 2 +- .../xd/batch/item/hadoop/SimpleAbstractHdfsItemWriter.java | 2 +- .../xd/batch/item/hadoop/SimpleHdfsTextItemWriter.java | 2 +- .../org/springframework/xd/hadoop/fs/AbstractHdfsWriter.java | 2 +- .../xd/hadoop/fs/DatasetDefinitionFactoryBean.java | 2 +- .../java/org/springframework/xd/hadoop/fs/DatasetWriter.java | 2 +- .../springframework/xd/hadoop/fs/DatasetWriterFactory.java | 2 +- .../org/springframework/xd/hadoop/fs/HdfsTextFileWriter.java | 2 +- .../xd/hadoop/fs/HdfsTextFileWriterFactory.java | 2 +- .../java/org/springframework/xd/hadoop/fs/HdfsWriter.java | 2 +- .../org/springframework/xd/hadoop/fs/HdfsWriterFactory.java | 2 +- .../integration/hadoop/IntegrationHadoopSystemConstants.java | 2 +- .../hadoop/config/DatasetOutboundChannelAdapterParser.java | 2 +- .../config/DatasetWritingMessageHandlerFactoryBean.java | 2 +- .../xd/integration/hadoop/config/HadoopNamespaceHandler.java | 2 +- .../hadoop/config/HdfsOutboundChannelAdapterParser.java | 2 +- .../config/HdfsStoreMessageHandlerBeanDefinitionBuilder.java | 2 +- .../hadoop/config/HdfsStoreMessageHandlerFactoryBean.java | 2 +- .../hadoop/config/HdfsWritingMessageHandlerFactoryBean.java | 2 +- .../hadoop/config/IntegrationHadoopNamespaceUtils.java | 2 +- .../xd/integration/hadoop/config/NamingStrategyParser.java | 2 +- .../xd/integration/hadoop/config/RolloverStrategyParser.java | 2 +- .../xd/integration/hadoop/config/StoreWriterFactoryBean.java | 2 +- .../xd/integration/hadoop/config/StoreWriterParser.java | 2 +- .../hadoop/expression/MessageExpressionMethods.java | 2 +- .../hadoop/expression/MessagePartitionKeyMethodResolver.java | 2 +- .../expression/MessagePartitionKeyPropertyAccessor.java | 2 +- .../hadoop/outbound/HdfsDataStoreMessageHandler.java | 2 +- .../hadoop/outbound/HdfsPartitionDataStoreMessageHandler.java | 2 +- .../integration/hadoop/outbound/HdfsStoreMessageHandler.java | 2 +- .../hadoop/outbound/HdfsWritingMessageHandler.java | 2 +- .../hadoop/partition/MessagePartitionStrategy.java | 2 +- .../springframework/xd/hadoop/fs/StubDatasetOperations.java | 2 +- .../java/org/springframework/xd/hadoop/fs/StubFileSystem.java | 2 +- .../config/DatasetOutboundChannelAdapterIntegrationTests.java | 2 +- .../config/DatasetOutboundChannelAdapterParserTests.java | 2 +- ...asetOutboundChannelAdapterPartitionedIntegrationTests.java | 2 +- .../config/HdfsOutboundChannelAdapterIntegrationTests.java | 2 +- .../hadoop/config/HdfsOutboundChannelAdapterParserTests.java | 2 +- .../integration/hadoop/config/NamingStrategyParserTests.java | 2 +- .../src/test/java/org/springframework/xd/test/TestPojo.java | 2 +- .../acceptance-test-sparkapp/src/main/java/spark/SparkPi.java | 2 +- .../xd/integration/fixtures/ContainerResolver.java | 2 +- .../org/springframework/xd/integration/fixtures/Jobs.java | 2 +- .../xd/integration/fixtures/ModuleFixture.java | 2 +- .../springframework/xd/integration/fixtures/ModuleType.java | 2 +- .../springframework/xd/integration/fixtures/Processors.java | 2 +- .../org/springframework/xd/integration/fixtures/Sinks.java | 2 +- .../org/springframework/xd/integration/fixtures/Sources.java | 2 +- .../org/springframework/xd/integration/util/ConfigUtil.java | 2 +- .../org/springframework/xd/integration/util/HadoopUtils.java | 2 +- .../xd/integration/util/InvalidResultException.java | 2 +- .../org/springframework/xd/integration/util/StreamUtils.java | 2 +- .../springframework/xd/integration/util/XdEc2Validation.java | 2 +- .../springframework/xd/integration/util/XdEnvironment.java | 2 +- .../xd/integration/util/jmxresult/JMXChannelResult.java | 2 +- .../xd/integration/util/jmxresult/JMXRequest.java | 2 +- .../xd/integration/util/jmxresult/JMXResult.java | 2 +- .../xd/integration/util/jmxresult/JMXValue.java | 2 +- .../springframework/xd/integration/util/jmxresult/Module.java | 2 +- .../xd/integration/test/AbstractIntegrationTest.java | 2 +- .../springframework/xd/integration/test/AbstractJobTest.java | 2 +- .../org/springframework/xd/integration/test/BasicJobTest.java | 2 +- .../org/springframework/xd/integration/test/CountTests.java | 2 +- .../org/springframework/xd/integration/test/FileJdbcTest.java | 2 +- .../springframework/xd/integration/test/FilePollHdfsTest.java | 2 +- .../springframework/xd/integration/test/FileSourceTest.java | 2 +- .../org/springframework/xd/integration/test/FtpHdfsTest.java | 2 +- .../org/springframework/xd/integration/test/GemfireTests.java | 2 +- .../org/springframework/xd/integration/test/HdfsJdbcTest.java | 2 +- .../springframework/xd/integration/test/HdfsMongoDbTest.java | 2 +- .../org/springframework/xd/integration/test/HdfsTest.java | 2 +- .../org/springframework/xd/integration/test/HttpTest.java | 2 +- .../xd/integration/test/IntegrationTestConfig.java | 2 +- .../org/springframework/xd/integration/test/JdbcHdfsTest.java | 2 +- .../org/springframework/xd/integration/test/JdbcTest.java | 2 +- .../java/org/springframework/xd/integration/test/JmsTest.java | 2 +- .../springframework/xd/integration/test/JobCommandTest.java | 2 +- .../org/springframework/xd/integration/test/KafkaTests.java | 2 +- .../org/springframework/xd/integration/test/MqttTest.java | 2 +- .../springframework/xd/integration/test/ProcessorTest.java | 2 +- .../org/springframework/xd/integration/test/RabbitTest.java | 2 +- .../springframework/xd/integration/test/SimpleJobTest.java | 2 +- .../springframework/xd/integration/test/SparkAppTests.java | 2 +- .../org/springframework/xd/integration/test/SyslogTest.java | 2 +- .../java/org/springframework/xd/integration/test/TapTest.java | 2 +- .../springframework/xd/integration/test/TcpClientTests.java | 2 +- .../java/org/springframework/xd/integration/test/TcpTest.java | 2 +- .../org/springframework/xd/integration/test/TickTockTest.java | 2 +- .../xd/integration/test/TwitterSearchTest.java | 2 +- .../xd/integration/test/TwitterStreamTest.java | 2 +- .../org/springframework/xd/integration/test/util/JMXTest.java | 2 +- .../xd/integration/test/util/package-info.java | 2 +- .../xd/dirt/integration/kafka/IntegerEncoderDecoder.java | 2 +- .../xd/dirt/integration/kafka/KafkaMessageBus.java | 2 +- .../xd/dirt/integration/bus/local/LocalMessageBus.java | 2 +- .../xd/dirt/integration/rabbit/ConnectionFactorySettings.java | 2 +- .../integration/rabbit/LocalizedQueueConnectionFactory.java | 2 +- .../xd/dirt/integration/rabbit/RabbitMessageBus.java | 2 +- .../LocalizedQueueConnectionFactoryIntegrationTests.java | 2 +- .../rabbit/LocalizedQueueConnectionFactoryTests.java | 2 +- .../xd/dirt/integration/redis/RedisMessageBus.java | 2 +- .../dirt/integration/bus/AbstractBusPropertiesAccessor.java | 2 +- .../org/springframework/xd/dirt/integration/bus/Binding.java | 2 +- .../xd/dirt/integration/bus/BusProperties.java | 2 +- .../org/springframework/xd/dirt/integration/bus/BusUtils.java | 2 +- .../dirt/integration/bus/EmbeddedHeadersMessageConverter.java | 2 +- .../springframework/xd/dirt/integration/bus/MessageBus.java | 2 +- .../xd/dirt/integration/bus/MessageBusException.java | 2 +- .../xd/dirt/integration/bus/MessageBusSupport.java | 2 +- .../xd/dirt/integration/bus/MessageValues.java | 2 +- .../dirt/integration/bus/PartitionKeyExtractorStrategy.java | 2 +- .../xd/dirt/integration/bus/PartitionSelectorStrategy.java | 2 +- .../xd/dirt/integration/bus/RabbitAdminException.java | 2 +- .../xd/dirt/integration/bus/RabbitManagementUtils.java | 2 +- .../xd/dirt/integration/bus/SerializationException.java | 2 +- .../integration/bus/StringConvertingContentTypeResolver.java | 2 +- .../springframework/xd/dirt/integration/bus/XdHeaders.java | 2 +- .../xd/dirt/integration/bus/MessageConverterTests.java | 2 +- .../options/mixins/BatchJobCommitIntervalOptionMixin.java | 2 +- .../module/options/mixins/BatchJobDeleteFilesOptionMixin.java | 2 +- .../options/mixins/BatchJobFieldDelimiterOptionMixin.java | 2 +- .../module/options/mixins/BatchJobFieldNamesOptionMixin.java | 2 +- .../module/options/mixins/BatchJobResourcesOptionMixin.java | 2 +- .../module/options/mixins/BatchJobRestartableOptionMixin.java | 2 +- .../mixins/BatchJobSinglestepPartitionSupportOptionMixin.java | 2 +- .../xd/module/options/mixins/DateFormatMixin.java | 2 +- .../xd/module/options/mixins/ExpressionOrScriptMixin.java | 2 +- .../xd/module/options/mixins/FromMongoDbOptionMixin.java | 2 +- .../xd/module/options/mixins/FromStringCharsetMixin.java | 2 +- .../xd/module/options/mixins/FtpConnectionMixin.java | 2 +- .../xd/module/options/mixins/HadoopConfigurationMixin.java | 2 +- .../xd/module/options/mixins/IntoMongoDbOptionMixin.java | 2 +- .../xd/module/options/mixins/MappedRequestHeadersMixin.java | 2 +- .../xd/module/options/mixins/MappedResponseHeadersMixin.java | 2 +- .../xd/module/options/mixins/MapreduceConfigurationMixin.java | 2 +- .../xd/module/options/mixins/MaxMessagesDefaultOneMixin.java | 2 +- .../options/mixins/MaxMessagesDefaultUnlimitedMixin.java | 2 +- .../xd/module/options/mixins/MongoDbConnectionMixin.java | 2 +- .../xd/module/options/mixins/PeriodicTriggerMixin.java | 2 +- .../springframework/xd/module/options/mixins/ScriptMixin.java | 2 +- .../xd/module/options/mixins/ToStringCharsetMixin.java | 2 +- .../java/org/springframework/xd/module/options/spi/Mixin.java | 2 +- .../springframework/xd/module/options/spi/ModuleOption.java | 2 +- .../xd/module/options/spi/ModulePlaceholders.java | 2 +- .../xd/module/options/spi/ProfileNamesProvider.java | 2 +- .../xd/module/options/spi/ValidationGroupsProvider.java | 2 +- .../org/springframework/xd/module/options/types/Password.java | 2 +- .../xd/module/options/validation/CronExpression.java | 2 +- .../xd/module/options/validation/DateFormat.java | 2 +- .../xd/module/options/validation/DateWithCustomFormat.java | 2 +- .../xd/module/options/validation/Exclusives.java | 2 +- .../xd/module/options/types/PasswordTests.java | 2 +- .../xd/module/options/validation/CronValidatorTests.java | 2 +- .../module/options/validation/DateFormatValidatorTests.java | 2 +- .../module/options/validation/DateWithCustomFormatTests.java | 2 +- .../springframework/xd/module/CompositeModuleDefinition.java | 2 +- .../java/org/springframework/xd/module/ModuleDefinition.java | 2 +- .../java/org/springframework/xd/module/ModuleDefinitions.java | 2 +- .../springframework/xd/module/ModuleDeploymentProperties.java | 2 +- .../java/org/springframework/xd/module/ModuleDescriptor.java | 2 +- .../main/java/org/springframework/xd/module/ModuleType.java | 2 +- .../xd/module/RuntimeModuleDeploymentProperties.java | 2 +- .../org/springframework/xd/module/SimpleModuleDefinition.java | 2 +- .../org/springframework/xd/module/core/AbstractModule.java | 2 +- .../org/springframework/xd/module/core/CompositeModule.java | 2 +- .../springframework/xd/module/core/JavaConfiguredModule.java | 2 +- .../main/java/org/springframework/xd/module/core/Module.java | 2 +- .../org/springframework/xd/module/core/ModuleEnvironment.java | 2 +- .../org/springframework/xd/module/core/ModuleFactory.java | 2 +- .../xd/module/core/NonBindingResourceConfiguredModule.java | 2 +- .../main/java/org/springframework/xd/module/core/Plugin.java | 2 +- .../xd/module/core/ResourceConfiguredModule.java | 2 +- .../java/org/springframework/xd/module/core/SimpleModule.java | 2 +- .../module/info/DefaultSimpleModuleInformationResolver.java | 2 +- .../xd/module/info/DelegatingModuleInformationResolver.java | 2 +- .../org/springframework/xd/module/info/ModuleInformation.java | 2 +- .../xd/module/info/ModuleInformationResolver.java | 2 +- .../module/options/DefaultModuleOptionsMetadataCollector.java | 2 +- .../module/options/DefaultModuleOptionsMetadataResolver.java | 2 +- .../options/DelegatingModuleOptionsMetadataResolver.java | 2 +- .../EnvironmentAwareModuleOptionsMetadataResolver.java | 2 +- .../options/FlattenedCompositeModuleOptionsMetadata.java | 2 +- .../options/HierarchicalCompositeModuleOptionsMetadata.java | 2 +- .../org/springframework/xd/module/options/ModuleOption.java | 2 +- .../org/springframework/xd/module/options/ModuleOptions.java | 2 +- .../xd/module/options/ModuleOptionsMetadata.java | 2 +- .../xd/module/options/ModuleOptionsMetadataResolver.java | 2 +- .../org/springframework/xd/module/options/ModuleUtils.java | 2 +- .../xd/module/options/PassthruModuleOptionsMetadata.java | 2 +- .../xd/module/options/PojoModuleOptionsMetadata.java | 2 +- .../xd/module/options/PrefixNarrowingModuleOptions.java | 2 +- .../xd/module/options/SimpleModuleOptionsMetadata.java | 2 +- .../support/StringToEnumIgnoringCaseConverterFactory.java | 2 +- .../xd/module/spark/streaming/package-info.java | 2 +- .../xd/module/support/ArchiveResourceLoader.java | 2 +- .../org/springframework/xd/module/support/DateTrigger.java | 2 +- .../xd/module/support/NestedArchiveResource.java | 2 +- .../springframework/xd/module/support/NullClassLoader.java | 2 +- .../xd/module/support/ParentLastURLClassLoader.java | 2 +- .../xd/module/core/ModuleEnvironmentTests.java | 2 +- .../springframework/xd/module/core/ModuleFactoryTests.java | 2 +- .../info/DefaultSimpleModuleInformationResolverTests.java | 2 +- .../module/info/DelegatingModuleInformationResolverTests.java | 2 +- .../xd/module/options/AlmostOverlappingPojo.java | 2 +- .../org/springframework/xd/module/options/BackingPojo.java | 2 +- .../options/DefaultModuleOptionsMetadataCollectorTests.java | 2 +- .../options/DefaultModuleOptionsMetadataResolverTests.java | 2 +- .../options/FlattenedCompositeModuleOptionsMetadataTests.java | 2 +- .../HierarchicalCompositeModuleOptionsMetadataTests.java | 2 +- .../xd/module/options/ModuleOptionMatchers.java | 2 +- .../springframework/xd/module/options/OtherBackingPojo.java | 2 +- .../springframework/xd/module/options/OverlappingPojo.java | 2 +- .../xd/module/options/PojoModuleOptionsMetadataTests.java | 2 +- .../xd/module/options/PojoWithAlmostOverlappingMixins.java | 2 +- .../org/springframework/xd/module/options/PojoWithMixin.java | 2 +- .../xd/module/options/PojoWithOverlappingMixins.java | 2 +- .../xd/module/options/PrefixNarrowingModuleOptionsTests.java | 2 +- .../xd/module/options/SimpleModuleOptionsMetadataTests.java | 2 +- .../xd/module/support/ArchiveResourceLoaderTests.java | 2 +- .../springframework/xd/module/support/DateTriggerTest.java | 2 +- .../springframework/xd/module/support/ModuleUtilsTests.java | 2 +- .../xd/module/support/ParentLastURLClassLoaderTests.java | 2 +- .../dynamic_classpath/source/foobar/config/foobar.properties | 2 +- .../xd/reactor/AbstractReactorMessageHandler.java | 2 +- .../springframework/xd/reactor/BroadcasterMessageHandler.java | 2 +- .../xd/reactor/MultipleBroadcasterMessageHandler.java | 2 +- .../main/java/org/springframework/xd/reactor/Processor.java | 2 +- .../springframework/xd/reactor/ReactorReflectionUtils.java | 2 +- .../xd/reactor/AbstractMessageHandlerTests.java | 2 +- .../xd/reactor/AbstractPongStringProcessor.java | 2 +- .../springframework/xd/reactor/AbstractRawTypeProcessor.java | 2 +- .../org/springframework/xd/reactor/AdditionalInterface.java | 2 +- .../xd/reactor/BroadcasterMessageHandlerTests.java | 2 +- .../xd/reactor/MultipleBroadcasterMessageHandlerTests.java | 2 +- .../org/springframework/xd/reactor/PongMessageProcessor.java | 2 +- .../org/springframework/xd/reactor/PongRawTypeProcessor.java | 2 +- .../org/springframework/xd/reactor/PongStringProcessor.java | 2 +- .../xd/rest/client/AggregateCounterOperations.java | 2 +- .../springframework/xd/rest/client/CompletionOperations.java | 2 +- .../org/springframework/xd/rest/client/CounterOperations.java | 2 +- .../xd/rest/client/FieldValueCounterOperations.java | 2 +- .../org/springframework/xd/rest/client/GaugeOperations.java | 2 +- .../org/springframework/xd/rest/client/JobOperations.java | 2 +- .../org/springframework/xd/rest/client/ModuleOperations.java | 2 +- .../springframework/xd/rest/client/ResourceOperations.java | 2 +- .../springframework/xd/rest/client/RichGaugeOperations.java | 2 +- .../org/springframework/xd/rest/client/RuntimeOperations.java | 2 +- .../springframework/xd/rest/client/SpringXDOperations.java | 2 +- .../org/springframework/xd/rest/client/StreamOperations.java | 2 +- .../xd/rest/client/impl/AbstractMetricTemplate.java | 2 +- .../xd/rest/client/impl/AbstractResourceTemplate.java | 2 +- .../xd/rest/client/impl/AbstractSingleMetricTemplate.java | 2 +- .../springframework/xd/rest/client/impl/AbstractTemplate.java | 2 +- .../xd/rest/client/impl/AggregateCounterTemplate.java | 2 +- .../xd/rest/client/impl/CompletionTemplate.java | 2 +- .../springframework/xd/rest/client/impl/CounterTemplate.java | 2 +- .../xd/rest/client/impl/FieldValueCounterTemplate.java | 2 +- .../springframework/xd/rest/client/impl/GaugeTemplate.java | 2 +- .../org/springframework/xd/rest/client/impl/JobTemplate.java | 2 +- .../springframework/xd/rest/client/impl/ModuleTemplate.java | 2 +- .../xd/rest/client/impl/RichGaugeTemplate.java | 2 +- .../springframework/xd/rest/client/impl/RuntimeTemplate.java | 2 +- .../xd/rest/client/impl/SpringXDException.java | 2 +- .../springframework/xd/rest/client/impl/SpringXDTemplate.java | 2 +- .../springframework/xd/rest/client/impl/StreamTemplate.java | 2 +- .../xd/rest/client/impl/VndErrorResponseErrorHandler.java | 2 +- .../client/impl/support/ExecutionContextJacksonMixIn.java | 2 +- .../xd/rest/client/impl/support/ExitStatusJacksonMixIn.java | 2 +- .../xd/rest/client/impl/support/JobExecutionJacksonMixIn.java | 2 +- .../xd/rest/client/impl/support/JobInstanceJacksonMixIn.java | 2 +- .../client/impl/support/JobParameterJacksonDeserializer.java | 2 +- .../xd/rest/client/impl/support/JobParameterJacksonMixIn.java | 2 +- .../rest/client/impl/support/JobParametersJacksonMixIn.java | 2 +- .../client/impl/support/StepExecutionHistoryJacksonMixIn.java | 2 +- .../rest/client/impl/support/StepExecutionJacksonMixIn.java | 2 +- .../xd/rest/client/impl/support/package-info.java | 2 +- .../xd/rest/client/impl/JobExecutionDeserializationTests.java | 2 +- .../springframework/xd/rest/client/impl/JobTemplateTests.java | 2 +- .../xd/rest/client/impl/StreamTemplateTests.java | 2 +- .../org/springframework/xd/rest/domain/CompletionKind.java | 2 +- .../springframework/xd/rest/domain/DeployableResource.java | 2 +- .../xd/rest/domain/DetailedContainerResource.java | 2 +- .../xd/rest/domain/DetailedJobInfoResource.java | 2 +- .../xd/rest/domain/DetailedModuleDefinitionResource.java | 2 +- .../xd/rest/domain/DocumentParseResultResource.java | 2 +- .../springframework/xd/rest/domain/JobDefinitionResource.java | 2 +- .../xd/rest/domain/JobExecutionInfoResource.java | 2 +- .../org/springframework/xd/rest/domain/JobInfoResource.java | 2 +- .../xd/rest/domain/JobInstanceInfoResource.java | 2 +- .../xd/rest/domain/ModuleDefinitionResource.java | 2 +- .../xd/rest/domain/ModuleMetadataResource.java | 2 +- .../org/springframework/xd/rest/domain/NamedResource.java | 2 +- .../springframework/xd/rest/domain/RESTDeploymentState.java | 2 +- .../org/springframework/xd/rest/domain/RESTModuleType.java | 2 +- .../xd/rest/domain/StepExecutionInfoResource.java | 2 +- .../xd/rest/domain/StepExecutionProgressInfoResource.java | 2 +- .../xd/rest/domain/StreamDefinitionResource.java | 2 +- .../java/org/springframework/xd/rest/domain/XDRuntime.java | 2 +- .../springframework/xd/rest/domain/meta/VersionResource.java | 2 +- .../xd/rest/domain/metrics/AggregateCountsResource.java | 2 +- .../xd/rest/domain/metrics/CounterResource.java | 2 +- .../xd/rest/domain/metrics/FieldValueCounterResource.java | 2 +- .../springframework/xd/rest/domain/metrics/GaugeResource.java | 2 +- .../xd/rest/domain/metrics/MetricResource.java | 2 +- .../xd/rest/domain/metrics/RichGaugeResource.java | 2 +- .../xd/rest/domain/security/SecurityInfoResource.java | 2 +- .../xd/rest/domain/support/DeploymentPropertiesFormat.java | 2 +- .../rest/domain/support/RestTemplateMessageConverterUtil.java | 2 +- .../rest/domain/util/ISO8601DateFormatWithMilliSeconds.java | 2 +- .../org/springframework/xd/rest/domain/util/TimeUtils.java | 2 +- .../xd/rest/domain/validation/CronValidation.java | 2 +- .../domain/StepExecutionInfoResourceSerializationTests.java | 2 +- .../xd/rxjava/MultipleSubjectMessageHandler.java | 2 +- .../main/java/org/springframework/xd/rxjava/Processor.java | 2 +- .../org/springframework/xd/rxjava/SubjectMessageHandler.java | 2 +- .../xd/rxjava/AbstractMessageHandlerTests.java | 2 +- .../xd/rxjava/MultipleSubjectMessageHandlerTests.java | 2 +- .../org/springframework/xd/rxjava/PongMessageProcessor.java | 2 +- .../org/springframework/xd/rxjava/PongStringProcessor.java | 2 +- .../springframework/xd/rxjava/SubjectMessageHandlerTests.java | 2 +- .../main/java/org/springframework/xd/shell/Configuration.java | 2 +- .../src/main/java/org/springframework/xd/shell/Target.java | 2 +- .../src/main/java/org/springframework/xd/shell/XDShell.java | 2 +- .../org/springframework/xd/shell/XDShellBannerProvider.java | 2 +- .../org/springframework/xd/shell/XDShellPromptProvider.java | 2 +- .../xd/shell/command/AbstractMetricsCommands.java | 2 +- .../xd/shell/command/AggregateCounterCommands.java | 2 +- .../org/springframework/xd/shell/command/ConfigCommands.java | 2 +- .../springframework/xd/shell/command/ConsoleUserInput.java | 2 +- .../org/springframework/xd/shell/command/CounterCommands.java | 2 +- .../xd/shell/command/DeploymentOptionKeys.java | 2 +- .../xd/shell/command/FieldValueCounterCommands.java | 2 +- .../org/springframework/xd/shell/command/GaugeCommands.java | 2 +- .../org/springframework/xd/shell/command/HttpCommands.java | 2 +- .../org/springframework/xd/shell/command/JobCommands.java | 2 +- .../org/springframework/xd/shell/command/ModuleCommands.java | 2 +- .../java/org/springframework/xd/shell/command/ModuleList.java | 2 +- .../springframework/xd/shell/command/RichGaugeCommands.java | 2 +- .../org/springframework/xd/shell/command/RuntimeCommands.java | 2 +- .../org/springframework/xd/shell/command/StreamCommands.java | 2 +- .../java/org/springframework/xd/shell/command/UserInput.java | 2 +- .../xd/shell/command/support/JobCommandsUtils.java | 2 +- .../xd/shell/converter/CompletionConverter.java | 2 +- .../xd/shell/converter/ExistingXDEntityConverter.java | 2 +- .../xd/shell/converter/MediaTypeConverter.java | 2 +- .../xd/shell/converter/NumberFormatConverter.java | 2 +- .../xd/shell/converter/QualifiedModuleNameConverter.java | 2 +- .../springframework/xd/shell/hadoop/ConfigurationAware.java | 2 +- .../xd/shell/hadoop/ConfigurationCommands.java | 2 +- .../xd/shell/hadoop/ConfigurationModifiedEvent.java | 2 +- .../org/springframework/xd/shell/hadoop/FsShellCommands.java | 2 +- .../java/org/springframework/xd/shell/util/Assertions.java | 2 +- .../java/org/springframework/xd/shell/util/CommonUtils.java | 2 +- .../main/java/org/springframework/xd/shell/util/JsonUtil.java | 2 +- .../main/java/org/springframework/xd/shell/util/Table.java | 2 +- .../java/org/springframework/xd/shell/util/TableHeader.java | 2 +- .../main/java/org/springframework/xd/shell/util/TableRow.java | 2 +- .../main/java/org/springframework/xd/shell/util/UiUtils.java | 2 +- .../xd/shell/AbstractShellIntegrationTest.java | 2 +- .../java/org/springframework/xd/shell/ModuleTypeTest.java | 2 +- .../xd/shell/bus/RabbitBusCleanerIntegrationTests.java | 2 +- .../xd/shell/command/AbstractCommandTemplate.java | 2 +- .../xd/shell/command/AbstractFileSourceAndFileSinkTests.java | 2 +- .../xd/shell/command/AbstractFtpModulesTests.java | 2 +- .../xd/shell/command/AbstractHttpCommandsTests.java | 2 +- .../shell/command/AbstractJarDeletingModuleCommandsTests.java | 2 +- .../xd/shell/command/AbstractJdbcModulesTests.java | 2 +- .../xd/shell/command/AbstractJobCommandsTests.java | 2 +- .../xd/shell/command/AbstractJobCommandsWithHadoopTests.java | 2 +- .../xd/shell/command/AbstractJobIntegrationTest.java | 2 +- .../xd/shell/command/AbstractKafkaSourceSinkTests.java | 2 +- .../xd/shell/command/AbstractMailCommandsTests.java | 2 +- .../xd/shell/command/AbstractMetricsTests.java | 2 +- .../xd/shell/command/AbstractModuleClasspathTests.java | 2 +- .../xd/shell/command/AbstractModuleCommandsTests.java | 2 +- .../xd/shell/command/AbstractNamedChannelTests.java | 2 +- .../xd/shell/command/AbstractProcessorsTests.java | 2 +- .../shell/command/AbstractRabbitSourceAndRabbitSinkTests.java | 2 +- .../xd/shell/command/AbstractRedisSinkTests.java | 2 +- .../xd/shell/command/AbstractRouterSinkTests.java | 2 +- .../xd/shell/command/AbstractRuntimeCommandsTests.java | 2 +- .../xd/shell/command/AbstractSftpSourceTests.java | 2 +- .../command/AbstractSpelPropertyAccessorIntegrationTests.java | 2 +- .../xd/shell/command/AbstractStreamCommandsTests.java | 2 +- .../xd/shell/command/AbstractStreamIntegrationTest.java | 2 +- .../xd/shell/command/AbstractTcpModulesTests.java | 2 +- .../xd/shell/command/AbstractTriggerModulesTests.java | 2 +- .../xd/shell/command/MessageStoreBenchmarkTests.java | 2 +- .../org/springframework/xd/shell/command/MetricsTemplate.java | 2 +- .../org/springframework/xd/shell/command/ModuleListTests.java | 2 +- .../org/springframework/xd/shell/command/ModuleTemplate.java | 2 +- .../java/org/springframework/xd/shell/command/MySuite.java | 2 +- .../org/springframework/xd/shell/command/SimpleTasklet.java | 2 +- .../xd/shell/command/SimpleTwoPartitionsPartitioner.java | 2 +- .../xd/shell/command/SpringBatchStepExecutionTestTasklet.java | 2 +- .../xd/shell/command/SpringBatchWithParametersTasklet.java | 2 +- .../xd/shell/command/StreamCommandsTemplate.java | 2 +- .../xd/shell/command/StreamCommandsUnitTests.java | 2 +- .../xd/shell/command/fixtures/FieldValueCounterSink.java | 2 +- .../springframework/xd/shell/command/fixtures/HttpSource.java | 2 +- .../xd/shell/command/fixtures/MetricExistsMatcher.java | 2 +- .../xd/shell/command/fixtures/RichGaugeSink.java | 2 +- .../springframework/xd/shell/command/fixtures/XDMatchers.java | 2 +- .../xd/shell/command/fixtures/package-info.java | 2 +- .../shell/command/nosecurity/FileSourceAndFileSinkTests.java | 2 +- .../xd/shell/command/nosecurity/FtpModulesTests.java | 2 +- .../xd/shell/command/nosecurity/HttpCommandsTests.java | 2 +- .../command/nosecurity/JarDeletingModuleCommandsTests.java | 2 +- .../xd/shell/command/nosecurity/JdbcModulesTests.java | 2 +- .../xd/shell/command/nosecurity/JobCommandsTests.java | 2 +- .../shell/command/nosecurity/JobCommandsWithHadoopTests.java | 2 +- .../xd/shell/command/nosecurity/KafkaSourceSinkTests.java | 2 +- .../xd/shell/command/nosecurity/MailCommandsTests.java | 2 +- .../xd/shell/command/nosecurity/MetricsTests.java | 2 +- .../xd/shell/command/nosecurity/ModuleClasspathTests.java | 2 +- .../xd/shell/command/nosecurity/ModuleCommandsTests.java | 2 +- .../xd/shell/command/nosecurity/NamedChannelTests.java | 2 +- .../xd/shell/command/nosecurity/ProcessorsTests.java | 2 +- .../command/nosecurity/RabbitSourceAndRabbitSinkTests.java | 2 +- .../xd/shell/command/nosecurity/RedisSinkTests.java | 2 +- .../xd/shell/command/nosecurity/RouterSinkTests.java | 2 +- .../xd/shell/command/nosecurity/RuntimeCommandsTests.java | 2 +- .../xd/shell/command/nosecurity/SftpSourceTests.java | 2 +- .../xd/shell/command/nosecurity/ShellCommandsTestSuite.java | 2 +- .../nosecurity/SpelPropertyAccessorIntegrationTests.java | 2 +- .../xd/shell/command/nosecurity/StreamCommandsTests.java | 2 +- .../xd/shell/command/nosecurity/TcpModulesTests.java | 2 +- .../xd/shell/command/nosecurity/TriggerModulesTests.java | 2 +- .../security/FileSourceAndFileSinkWithSecurityTests.java | 2 +- .../shell/command/security/FtpModulesWithSecurityTests.java | 2 +- .../shell/command/security/HttpCommandsWithSecurityTests.java | 2 +- .../security/JarDeletingModuleCommandsWithSecurityTests.java | 2 +- .../shell/command/security/JdbcModulesWithSecurityTests.java | 2 +- .../security/JobCommandsWithHadoopAndSecurityTests.java | 2 +- .../shell/command/security/JobCommandsWithSecurityTests.java | 2 +- .../command/security/KafkaSourceSinkWithSecurityTests.java | 2 +- .../shell/command/security/MailCommandsWithSecurityTests.java | 2 +- .../xd/shell/command/security/MetricsWithSecurityTests.java | 2 +- .../command/security/ModuleClasspathWithSecurityTests.java | 2 +- .../command/security/ModuleCommandsWithSecurityTests.java | 2 +- .../shell/command/security/NamedChannelWithSecurityTests.java | 2 +- .../shell/command/security/ProcessorsWithSecurityTests.java | 2 +- .../security/RabbitSourceAndRabbitSinkWithSecurityTests.java | 2 +- .../xd/shell/command/security/RedisSinkWithSecurityTests.java | 2 +- .../shell/command/security/RouterSinkWithSecurityTests.java | 2 +- .../command/security/RuntimeCommandsWithSecurityTests.java | 2 +- .../shell/command/security/SftpSourceWithSecurityTests.java | 2 +- .../command/security/ShellCommandsWithSecurityTestSuite.java | 2 +- .../SpelPropertyAccessorIntegrationWithSecurityTests.java | 2 +- .../command/security/StreamCommandsWithSecurityTests.java | 2 +- .../shell/command/security/TcpModulesWithSecurityTests.java | 2 +- .../command/security/TriggerModulesWithSecurityTests.java | 2 +- .../xd/shell/command/support/JobCommandsUtilsTests.java | 2 +- .../xd/shell/security/SecuredShellAccessTestSuite.java | 2 +- .../xd/shell/security/SecuredShellAccessTests.java | 2 +- .../xd/shell/security/SecuredShellAccessWithSslTests.java | 2 +- .../xd/shell/util/CliAvailabilityIndicatorChecker.java | 2 +- .../org/springframework/xd/shell/util/CommonUtilsTest.java | 2 +- .../java/org/springframework/xd/shell/util/TableMatchers.java | 2 +- .../java/org/springframework/xd/shell/util/TestFtpServer.java | 2 +- .../org/springframework/xd/shell/util/TestSftpServer.java | 2 +- .../java/org/springframework/xd/shell/util/UiUtilsTest.java | 2 +- .../xd/spark/streaming/AbstractSparkStreamingTests.java | 2 +- .../xd/spark/streaming/KafkaTransportSparkStreamingTests.java | 2 +- .../xd/spark/streaming/LocalTransportSparkStreamingTests.java | 2 +- .../spark/streaming/RabbitTransportSparkStreamingTests.java | 2 +- .../xd/spark/streaming/RedisTransportSparkStreamingTests.java | 2 +- .../streaming/DefaultSparkStreamingModuleOptionsMetadata.java | 2 +- .../org/springframework/xd/spark/streaming/SparkConfig.java | 2 +- .../xd/spark/streaming/SparkMessageSender.java | 2 +- .../xd/spark/streaming/SparkStreamingModuleExecutor.java | 2 +- .../xd/spark/streaming/SparkStreamingSupport.java | 2 +- .../xd/spark/streaming/examples/java/FileLogger.java | 2 +- .../examples/java/FileLoggerModuleOptionsMetadata.java | 2 +- .../xd/spark/streaming/examples/java/WordCount.java | 2 +- .../xd/spark/streaming/java/ModuleExecutor.java | 2 +- .../springframework/xd/spark/streaming/java/Processor.java | 2 +- .../xd/spark/streaming/examples/scala/FileLogger.scala | 2 +- .../xd/spark/streaming/examples/scala/WordCount.scala | 2 +- .../xd/spark/streaming/scala/ModuleExecutor.scala | 2 +- .../springframework/xd/spark/streaming/scala/Processor.scala | 2 +- .../springframework/xd/test/fixtures/AbstractMailSource.java | 2 +- .../springframework/xd/test/fixtures/AbstractMetricSink.java | 2 +- .../xd/test/fixtures/AbstractModuleFixture.java | 2 +- .../xd/test/fixtures/AggregateCounterSink.java | 2 +- .../org/springframework/xd/test/fixtures/CounterSink.java | 2 +- .../java/org/springframework/xd/test/fixtures/Disposable.java | 2 +- .../xd/test/fixtures/DisposableFileSupport.java | 2 +- .../xd/test/fixtures/DisposableMailSupport.java | 2 +- .../springframework/xd/test/fixtures/EventuallyMatcher.java | 2 +- .../org/springframework/xd/test/fixtures/FileJdbcJob.java | 2 +- .../org/springframework/xd/test/fixtures/FilePollHdfsJob.java | 4 ++-- .../java/org/springframework/xd/test/fixtures/FileSink.java | 2 +- .../java/org/springframework/xd/test/fixtures/FileSource.java | 2 +- .../springframework/xd/test/fixtures/FtpDummyUserManager.java | 2 +- .../java/org/springframework/xd/test/fixtures/FtpHdfsJob.java | 4 ++-- .../java/org/springframework/xd/test/fixtures/FtpSink.java | 2 +- .../java/org/springframework/xd/test/fixtures/FtpSource.java | 2 +- .../org/springframework/xd/test/fixtures/GemFireCQSource.java | 2 +- .../springframework/xd/test/fixtures/GemFireServerSink.java | 2 +- .../org/springframework/xd/test/fixtures/GemFireSource.java | 2 +- .../org/springframework/xd/test/fixtures/HasDisplayValue.java | 2 +- .../org/springframework/xd/test/fixtures/HdfsJdbcJob.java | 2 +- .../org/springframework/xd/test/fixtures/HdfsMongoDbJob.java | 2 +- .../java/org/springframework/xd/test/fixtures/HdfsSink.java | 2 +- .../xd/test/fixtures/IncrementalJdbcHdfsJob.java | 2 +- .../org/springframework/xd/test/fixtures/JdbcHdfsJob.java | 2 +- .../java/org/springframework/xd/test/fixtures/JdbcSink.java | 2 +- .../java/org/springframework/xd/test/fixtures/JdbcSource.java | 2 +- .../java/org/springframework/xd/test/fixtures/JmsSource.java | 2 +- .../java/org/springframework/xd/test/fixtures/KafkaSink.java | 2 +- .../org/springframework/xd/test/fixtures/KafkaSource.java | 2 +- .../java/org/springframework/xd/test/fixtures/LogSink.java | 2 +- .../java/org/springframework/xd/test/fixtures/MailSink.java | 2 +- .../xd/test/fixtures/MetricHasSimpleValueMatcher.java | 2 +- .../java/org/springframework/xd/test/fixtures/MqttSink.java | 2 +- .../java/org/springframework/xd/test/fixtures/MqttSource.java | 2 +- .../xd/test/fixtures/NonPollingImapSource.java | 2 +- .../xd/test/fixtures/PartitionedJdbcHdfsJob.java | 2 +- .../springframework/xd/test/fixtures/PollingMailSource.java | 2 +- .../java/org/springframework/xd/test/fixtures/RabbitSink.java | 2 +- .../org/springframework/xd/test/fixtures/RabbitSource.java | 2 +- .../springframework/xd/test/fixtures/SimpleCounterSink.java | 2 +- .../org/springframework/xd/test/fixtures/SimpleFileSink.java | 2 +- .../springframework/xd/test/fixtures/SimpleFileSource.java | 2 +- .../springframework/xd/test/fixtures/SimpleHttpSource.java | 2 +- .../springframework/xd/test/fixtures/SimpleTailSource.java | 2 +- .../org/springframework/xd/test/fixtures/SparkAppJob.java | 2 +- .../org/springframework/xd/test/fixtures/SyslogTcpSource.java | 2 +- .../org/springframework/xd/test/fixtures/SyslogUdpSource.java | 2 +- .../java/org/springframework/xd/test/fixtures/TailSource.java | 2 +- .../main/java/org/springframework/xd/test/fixtures/Tap.java | 2 +- .../org/springframework/xd/test/fixtures/TcpClientSource.java | 2 +- .../java/org/springframework/xd/test/fixtures/TcpSink.java | 2 +- .../java/org/springframework/xd/test/fixtures/TcpSource.java | 2 +- .../java/org/springframework/xd/test/fixtures/Transform.java | 2 +- .../springframework/xd/test/fixtures/TwitterSearchSource.java | 2 +- .../springframework/xd/test/fixtures/TwitterStreamSource.java | 2 +- .../xd/test/fixtures/util/AvailableSocketPorts.java | 2 +- .../springframework/xd/test/fixtures/util/FixtureUtils.java | 2 +- .../org/springframework/xd/test/fixtures/util/KafkaUtils.java | 2 +- .../springframework/xd/test/generator/GeneratorException.java | 2 +- .../org/springframework/xd/test/generator/HttpGenerator.java | 2 +- .../xd/test/generator/SimpleHttpGenerator.java | 2 +- .../java/org/springframework/xd/test/fixtures/TapTest.java | 2 +- .../xd/test/fixtures/util/FixtureUtilsTests.java | 2 +- .../springframework/xd/dirt/integration/bus/BusTestUtils.java | 2 +- .../org/springframework/xd/module/TestModuleDefinitions.java | 2 +- .../xd/test/AbstractExternalResourceTestSupport.java | 2 +- .../java/org/springframework/xd/test/HostNotWindowsRule.java | 2 +- .../java/org/springframework/xd/test/PackageSuiteRunner.java | 2 +- .../springframework/xd/test/RandomConfigurationSupport.java | 2 +- .../org/springframework/xd/test/kafka/EmbeddedZookeeper.java | 2 +- .../org/springframework/xd/test/kafka/KafkaTestSupport.java | 2 +- .../org/springframework/xd/test/mqtt/MqttTestSupport.java | 2 +- .../xd/test/rabbit/RabbitAdminTestSupport.java | 2 +- .../org/springframework/xd/test/rabbit/RabbitTestSupport.java | 2 +- .../org/springframework/xd/test/redis/RedisTestSupport.java | 2 +- .../main/java/org/springframework/xd/tuple/DefaultTuple.java | 2 +- .../xd/tuple/DefaultTupleConversionService.java | 2 +- .../springframework/xd/tuple/JsonBytesToTupleConverter.java | 2 +- .../springframework/xd/tuple/JsonNodeToTupleConverter.java | 2 +- .../springframework/xd/tuple/JsonStringToTupleConverter.java | 2 +- .../xd/tuple/LocaleAwareStringToNumberConverterFactory.java | 2 +- .../org/springframework/xd/tuple/StringToDateConverter.java | 2 +- .../src/main/java/org/springframework/xd/tuple/Tuple.java | 2 +- .../main/java/org/springframework/xd/tuple/TupleBuilder.java | 2 +- .../org/springframework/xd/tuple/TupleJsonMarshaller.java | 2 +- .../org/springframework/xd/tuple/TupleStringMarshaller.java | 2 +- .../springframework/xd/tuple/TupleToJsonStringConverter.java | 2 +- .../java/org/springframework/xd/tuple/batch/FieldSetType.java | 2 +- .../springframework/xd/tuple/batch/TupleFieldExtractor.java | 2 +- .../springframework/xd/tuple/batch/TupleFieldSetMapper.java | 2 +- .../org/springframework/xd/tuple/batch/TupleRowMapper.java | 2 +- .../xd/tuple/batch/TupleSqlParameterSource.java | 2 +- .../xd/tuple/batch/TupleSqlParameterSourceProvider.java | 2 +- .../xd/tuple/integration/JsonToTupleTransformer.java | 2 +- .../xd/tuple/integration/MapToTupleTransformer.java | 2 +- .../springframework/xd/tuple/processor/TupleProcessor.java | 2 +- .../xd/tuple/serializer/kryo/DefaultTupleSerializer.java | 2 +- .../xd/tuple/serializer/kryo/TupleKryoRegistrar.java | 2 +- .../xd/tuple/serializer/kryo/package-info.java | 2 +- .../springframework/xd/tuple/spel/TuplePropertyAccessor.java | 2 +- .../xd/tuple/AbstractTupleMarshallerTests.java | 2 +- .../springframework/xd/tuple/DefaultTupleTestForBatch.java | 2 +- .../java/org/springframework/xd/tuple/DefaultTupleTests.java | 2 +- .../xd/tuple/JsonBytesToTupleConverterTests.java | 2 +- .../springframework/xd/tuple/SpringToDateConverterTests.java | 2 +- .../springframework/xd/tuple/TupleJsonMarshallerTests.java | 2 +- .../xd/tuple/batch/TupleFieldExtractorTests.java | 2 +- .../xd/tuple/batch/TupleFieldSetMapperTests.java | 2 +- .../springframework/xd/tuple/batch/TupleRowMapperTests.java | 2 +- .../xd/tuple/integration/JsonToTupleTransformerTests.java | 2 +- .../xd/tuple/integration/MapToTupleTransformerTests.java | 2 +- .../xd/tuple/serializer/kryo/TupleCodecTests.java | 2 +- .../xd/tuple/spel/TuplePropertyAccessorTests.java | 2 +- .../java/org/springframework/xd/dirt/web/StandAloneUiApp.java | 2 +- .../org/springframework/xd/dirt/web/WebConfiguration.java | 2 +- .../xd/dirt/web/config/SecurityConfiguration.java | 2 +- .../org/springframework/xd/dirt/web/config/package-info.java | 2 +- .../xd/dirt/web/controller/LoginController.java | 2 +- .../springframework/xd/dirt/web/controller/package-info.java | 2 +- .../xd/dirt/web/controller/support/AuthenticationRequest.java | 2 +- .../xd/dirt/web/controller/support/package-info.java | 2 +- .../java/org/springframework/xd/dirt/web/package-info.java | 2 +- .../xd/dirt/web/SecurityConfigurationTests.java | 2 +- .../xd/dirt/web/SecurityDisabledConfigurationTests.java | 2 +- .../org/springframework/xd/yarn/AppmasterApplication.java | 2 +- .../main/java/org/springframework/xd/yarn/XdAppmaster.java | 2 +- .../java/org/springframework/xd/yarn/ClientApplication.java | 2 +- .../org/springframework/xd/yarn/XdYarnAdminInfoCommand.java | 2 +- .../springframework/xd/yarn/XdYarnClusterCreateCommand.java | 2 +- src/docs/asciidoc/Introduction.asciidoc | 2 +- src/etc/header.txt | 2 +- 1442 files changed, 1445 insertions(+), 1445 deletions(-) diff --git a/CONTRIBUTING.md b/CONTRIBUTING.md index 1339f97c7..a66b0a12a 100644 --- a/CONTRIBUTING.md +++ b/CONTRIBUTING.md @@ -146,7 +146,7 @@ Please carefully follow the whitespace and formatting conventions already presen * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/README.md b/README.md index 4eb24f678..fd038d751 100644 --- a/README.md +++ b/README.md @@ -50,5 +50,5 @@ Source Metrics are available via Sonar at: [Spring XD JIRA]: https://jira.springsource.org/browse/XD -[Apache License]: http://www.apache.org/licenses/LICENSE-2.0 +[Apache License]: https://www.apache.org/licenses/LICENSE-2.0 [Spring Data Book]: http://bit.ly/sd-book diff --git a/config/sqoop-site.xml b/config/sqoop-site.xml index e5fcfa2f0..cff42db1b 100644 --- a/config/sqoop-site.xml +++ b/config/sqoop-site.xml @@ -9,7 +9,7 @@ to you under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with the License. You may obtain a copy of the License at - http://www.apache.org/licenses/LICENSE-2.0 + https://www.apache.org/licenses/LICENSE-2.0 Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on an diff --git a/documentation-toolchain/src/main/java/org/springframework/xd/documentation/AsciidocLinkChecker.java b/documentation-toolchain/src/main/java/org/springframework/xd/documentation/AsciidocLinkChecker.java index 9a76dc324..bcd54f3fd 100644 --- a/documentation-toolchain/src/main/java/org/springframework/xd/documentation/AsciidocLinkChecker.java +++ b/documentation-toolchain/src/main/java/org/springframework/xd/documentation/AsciidocLinkChecker.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/documentation-toolchain/src/main/java/org/springframework/xd/documentation/ModuleOptionsReferenceDoc.java b/documentation-toolchain/src/main/java/org/springframework/xd/documentation/ModuleOptionsReferenceDoc.java index 7f962823d..74d9bf2c5 100644 --- a/documentation-toolchain/src/main/java/org/springframework/xd/documentation/ModuleOptionsReferenceDoc.java +++ b/documentation-toolchain/src/main/java/org/springframework/xd/documentation/ModuleOptionsReferenceDoc.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/documentation-toolchain/src/test/java/org/springframework/xd/documentation/ShellReferenceDoc.java b/documentation-toolchain/src/test/java/org/springframework/xd/documentation/ShellReferenceDoc.java index 0b2c1ecce..be17a5e81 100644 --- a/documentation-toolchain/src/test/java/org/springframework/xd/documentation/ShellReferenceDoc.java +++ b/documentation-toolchain/src/test/java/org/springframework/xd/documentation/ShellReferenceDoc.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-batch/src/main/java/org/springframework/batch/integration/x/IncrementalColumnRangePartitioner.java b/extensions/spring-xd-extension-batch/src/main/java/org/springframework/batch/integration/x/IncrementalColumnRangePartitioner.java index 213be8b51..ea07dc62a 100644 --- a/extensions/spring-xd-extension-batch/src/main/java/org/springframework/batch/integration/x/IncrementalColumnRangePartitioner.java +++ b/extensions/spring-xd-extension-batch/src/main/java/org/springframework/batch/integration/x/IncrementalColumnRangePartitioner.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-batch/src/main/java/org/springframework/batch/integration/x/RemoteFilePartitioner.java b/extensions/spring-xd-extension-batch/src/main/java/org/springframework/batch/integration/x/RemoteFilePartitioner.java index ec09be77c..1dd1bd23f 100644 --- a/extensions/spring-xd-extension-batch/src/main/java/org/springframework/batch/integration/x/RemoteFilePartitioner.java +++ b/extensions/spring-xd-extension-batch/src/main/java/org/springframework/batch/integration/x/RemoteFilePartitioner.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-batch/src/main/java/org/springframework/batch/integration/x/RemoteFileToHadoopTasklet.java b/extensions/spring-xd-extension-batch/src/main/java/org/springframework/batch/integration/x/RemoteFileToHadoopTasklet.java index 106f89084..fbd327f7e 100644 --- a/extensions/spring-xd-extension-batch/src/main/java/org/springframework/batch/integration/x/RemoteFileToHadoopTasklet.java +++ b/extensions/spring-xd-extension-batch/src/main/java/org/springframework/batch/integration/x/RemoteFileToHadoopTasklet.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-batch/src/main/java/org/springframework/batch/integration/x/TimestampFileTasklet.java b/extensions/spring-xd-extension-batch/src/main/java/org/springframework/batch/integration/x/TimestampFileTasklet.java index 96f60d7c3..937397aa5 100644 --- a/extensions/spring-xd-extension-batch/src/main/java/org/springframework/batch/integration/x/TimestampFileTasklet.java +++ b/extensions/spring-xd-extension-batch/src/main/java/org/springframework/batch/integration/x/TimestampFileTasklet.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-batch/src/main/java/org/springframework/batch/step/tasklet/x/AbstractProcessBuilderTasklet.java b/extensions/spring-xd-extension-batch/src/main/java/org/springframework/batch/step/tasklet/x/AbstractProcessBuilderTasklet.java index e7f46e3a8..b75a100e3 100644 --- a/extensions/spring-xd-extension-batch/src/main/java/org/springframework/batch/step/tasklet/x/AbstractProcessBuilderTasklet.java +++ b/extensions/spring-xd-extension-batch/src/main/java/org/springframework/batch/step/tasklet/x/AbstractProcessBuilderTasklet.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-batch/src/main/java/org/springframework/batch/step/tasklet/x/ClasspathEnvironmentProvider.java b/extensions/spring-xd-extension-batch/src/main/java/org/springframework/batch/step/tasklet/x/ClasspathEnvironmentProvider.java index c4612db0b..fd9641dd6 100644 --- a/extensions/spring-xd-extension-batch/src/main/java/org/springframework/batch/step/tasklet/x/ClasspathEnvironmentProvider.java +++ b/extensions/spring-xd-extension-batch/src/main/java/org/springframework/batch/step/tasklet/x/ClasspathEnvironmentProvider.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-batch/src/main/java/org/springframework/batch/step/tasklet/x/EnvironmentProvider.java b/extensions/spring-xd-extension-batch/src/main/java/org/springframework/batch/step/tasklet/x/EnvironmentProvider.java index ff6ff5e36..b900e18df 100644 --- a/extensions/spring-xd-extension-batch/src/main/java/org/springframework/batch/step/tasklet/x/EnvironmentProvider.java +++ b/extensions/spring-xd-extension-batch/src/main/java/org/springframework/batch/step/tasklet/x/EnvironmentProvider.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-batch/src/test/java/org/springframework/batch/integration/x/IncrementalColumnRangePartitionerConfiguration.java b/extensions/spring-xd-extension-batch/src/test/java/org/springframework/batch/integration/x/IncrementalColumnRangePartitionerConfiguration.java index c8e5c256c..43cbdc79c 100644 --- a/extensions/spring-xd-extension-batch/src/test/java/org/springframework/batch/integration/x/IncrementalColumnRangePartitionerConfiguration.java +++ b/extensions/spring-xd-extension-batch/src/test/java/org/springframework/batch/integration/x/IncrementalColumnRangePartitionerConfiguration.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-batch/src/test/java/org/springframework/batch/integration/x/IncrementalColumnRangePartitionerTest.java b/extensions/spring-xd-extension-batch/src/test/java/org/springframework/batch/integration/x/IncrementalColumnRangePartitionerTest.java index 81200f929..caa4c408e 100644 --- a/extensions/spring-xd-extension-batch/src/test/java/org/springframework/batch/integration/x/IncrementalColumnRangePartitionerTest.java +++ b/extensions/spring-xd-extension-batch/src/test/java/org/springframework/batch/integration/x/IncrementalColumnRangePartitionerTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-batch/src/test/java/org/springframework/batch/integration/x/RemoteFileToHadoopTaskletTests.java b/extensions/spring-xd-extension-batch/src/test/java/org/springframework/batch/integration/x/RemoteFileToHadoopTaskletTests.java index c2c70cbe6..6e5332cb3 100644 --- a/extensions/spring-xd-extension-batch/src/test/java/org/springframework/batch/integration/x/RemoteFileToHadoopTaskletTests.java +++ b/extensions/spring-xd-extension-batch/src/test/java/org/springframework/batch/integration/x/RemoteFileToHadoopTaskletTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-batch/src/test/java/org/springframework/batch/integration/x/RemoteFileToHadoopTests.java b/extensions/spring-xd-extension-batch/src/test/java/org/springframework/batch/integration/x/RemoteFileToHadoopTests.java index 501cfb425..7edaded31 100644 --- a/extensions/spring-xd-extension-batch/src/test/java/org/springframework/batch/integration/x/RemoteFileToHadoopTests.java +++ b/extensions/spring-xd-extension-batch/src/test/java/org/springframework/batch/integration/x/RemoteFileToHadoopTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-batch/src/test/java/org/springframework/batch/integration/x/RemoteFileToTmpTests.java b/extensions/spring-xd-extension-batch/src/test/java/org/springframework/batch/integration/x/RemoteFileToTmpTests.java index 05b459e8a..296a2fda7 100644 --- a/extensions/spring-xd-extension-batch/src/test/java/org/springframework/batch/integration/x/RemoteFileToTmpTests.java +++ b/extensions/spring-xd-extension-batch/src/test/java/org/springframework/batch/integration/x/RemoteFileToTmpTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-cassandra/src/main/java/org/springframework/xd/cassandra/CassandraConfiguration.java b/extensions/spring-xd-extension-cassandra/src/main/java/org/springframework/xd/cassandra/CassandraConfiguration.java index ef0fcbf5b..3ba491c86 100644 --- a/extensions/spring-xd-extension-cassandra/src/main/java/org/springframework/xd/cassandra/CassandraConfiguration.java +++ b/extensions/spring-xd-extension-cassandra/src/main/java/org/springframework/xd/cassandra/CassandraConfiguration.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-cassandra/src/main/java/org/springframework/xd/cassandra/CassandraSinkConfiguration.java b/extensions/spring-xd-extension-cassandra/src/main/java/org/springframework/xd/cassandra/CassandraSinkConfiguration.java index afece21fc..5cef67ff6 100644 --- a/extensions/spring-xd-extension-cassandra/src/main/java/org/springframework/xd/cassandra/CassandraSinkConfiguration.java +++ b/extensions/spring-xd-extension-cassandra/src/main/java/org/springframework/xd/cassandra/CassandraSinkConfiguration.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-cassandra/src/main/java/org/springframework/xd/cassandra/CassandraSinkOptionsMetadata.java b/extensions/spring-xd-extension-cassandra/src/main/java/org/springframework/xd/cassandra/CassandraSinkOptionsMetadata.java index 54ee182bc..34f22e55f 100644 --- a/extensions/spring-xd-extension-cassandra/src/main/java/org/springframework/xd/cassandra/CassandraSinkOptionsMetadata.java +++ b/extensions/spring-xd-extension-cassandra/src/main/java/org/springframework/xd/cassandra/CassandraSinkOptionsMetadata.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-cassandra/src/main/java/org/springframework/xd/cassandra/mixins/CassandraConnectionMixin.java b/extensions/spring-xd-extension-cassandra/src/main/java/org/springframework/xd/cassandra/mixins/CassandraConnectionMixin.java index 050231c3e..50136e7a9 100644 --- a/extensions/spring-xd-extension-cassandra/src/main/java/org/springframework/xd/cassandra/mixins/CassandraConnectionMixin.java +++ b/extensions/spring-xd-extension-cassandra/src/main/java/org/springframework/xd/cassandra/mixins/CassandraConnectionMixin.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-cassandra/src/test/java/org/springframework/xd/cassandra/CassandraSinkModulePropertiesTests.java b/extensions/spring-xd-extension-cassandra/src/test/java/org/springframework/xd/cassandra/CassandraSinkModulePropertiesTests.java index afedf7497..e624b9dca 100644 --- a/extensions/spring-xd-extension-cassandra/src/test/java/org/springframework/xd/cassandra/CassandraSinkModulePropertiesTests.java +++ b/extensions/spring-xd-extension-cassandra/src/test/java/org/springframework/xd/cassandra/CassandraSinkModulePropertiesTests.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-cassandra/src/test/java/org/springframework/xd/cassandra/CassandraSinkTests.java b/extensions/spring-xd-extension-cassandra/src/test/java/org/springframework/xd/cassandra/CassandraSinkTests.java index 9b3184332..3c44b7499 100644 --- a/extensions/spring-xd-extension-cassandra/src/test/java/org/springframework/xd/cassandra/CassandraSinkTests.java +++ b/extensions/spring-xd-extension-cassandra/src/test/java/org/springframework/xd/cassandra/CassandraSinkTests.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-cassandra/src/test/java/org/springframework/xd/test/domain/Book.java b/extensions/spring-xd-extension-cassandra/src/test/java/org/springframework/xd/test/domain/Book.java index a2b7803b2..9f98a15de 100644 --- a/extensions/spring-xd-extension-cassandra/src/test/java/org/springframework/xd/test/domain/Book.java +++ b/extensions/spring-xd-extension-cassandra/src/test/java/org/springframework/xd/test/domain/Book.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-encoder-support/src/main/java/org/springframework/xd/tcp/encdec/EncoderDecoderMixins.java b/extensions/spring-xd-extension-encoder-support/src/main/java/org/springframework/xd/tcp/encdec/EncoderDecoderMixins.java index a77d3d8a3..f5087062f 100644 --- a/extensions/spring-xd-extension-encoder-support/src/main/java/org/springframework/xd/tcp/encdec/EncoderDecoderMixins.java +++ b/extensions/spring-xd-extension-encoder-support/src/main/java/org/springframework/xd/tcp/encdec/EncoderDecoderMixins.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gemfire/src/main/java/org/springframework/integration/x/gemfire/JsonStringToObjectTransformer.java b/extensions/spring-xd-extension-gemfire/src/main/java/org/springframework/integration/x/gemfire/JsonStringToObjectTransformer.java index 0cbf69a5a..2b4184b3a 100644 --- a/extensions/spring-xd-extension-gemfire/src/main/java/org/springframework/integration/x/gemfire/JsonStringToObjectTransformer.java +++ b/extensions/spring-xd-extension-gemfire/src/main/java/org/springframework/integration/x/gemfire/JsonStringToObjectTransformer.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/extensions/spring-xd-extension-gemfire/src/main/java/org/springframework/xd/gemfire/GemfireCQSourceOptionsMetadata.java b/extensions/spring-xd-extension-gemfire/src/main/java/org/springframework/xd/gemfire/GemfireCQSourceOptionsMetadata.java index d5d16044c..ddd951e5e 100644 --- a/extensions/spring-xd-extension-gemfire/src/main/java/org/springframework/xd/gemfire/GemfireCQSourceOptionsMetadata.java +++ b/extensions/spring-xd-extension-gemfire/src/main/java/org/springframework/xd/gemfire/GemfireCQSourceOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gemfire/src/main/java/org/springframework/xd/gemfire/GemfireHostPortMixin.java b/extensions/spring-xd-extension-gemfire/src/main/java/org/springframework/xd/gemfire/GemfireHostPortMixin.java index 186cf0c96..efff2b150 100644 --- a/extensions/spring-xd-extension-gemfire/src/main/java/org/springframework/xd/gemfire/GemfireHostPortMixin.java +++ b/extensions/spring-xd-extension-gemfire/src/main/java/org/springframework/xd/gemfire/GemfireHostPortMixin.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gemfire/src/main/java/org/springframework/xd/gemfire/GemfireServerSinkModuleOptionsMetadata.java b/extensions/spring-xd-extension-gemfire/src/main/java/org/springframework/xd/gemfire/GemfireServerSinkModuleOptionsMetadata.java index 4d8978539..3c1841e70 100644 --- a/extensions/spring-xd-extension-gemfire/src/main/java/org/springframework/xd/gemfire/GemfireServerSinkModuleOptionsMetadata.java +++ b/extensions/spring-xd-extension-gemfire/src/main/java/org/springframework/xd/gemfire/GemfireServerSinkModuleOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gemfire/src/main/java/org/springframework/xd/gemfire/GemfireSourceOptionsMetadata.java b/extensions/spring-xd-extension-gemfire/src/main/java/org/springframework/xd/gemfire/GemfireSourceOptionsMetadata.java index 7d5b555ef..6fbcd371d 100644 --- a/extensions/spring-xd-extension-gemfire/src/main/java/org/springframework/xd/gemfire/GemfireSourceOptionsMetadata.java +++ b/extensions/spring-xd-extension-gemfire/src/main/java/org/springframework/xd/gemfire/GemfireSourceOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gemfire/src/test/java/org/springframework/integration/x/gemfire/JsonStringToObjectTransformerTests.java b/extensions/spring-xd-extension-gemfire/src/test/java/org/springframework/integration/x/gemfire/JsonStringToObjectTransformerTests.java index 80360c1f2..fa3338155 100644 --- a/extensions/spring-xd-extension-gemfire/src/test/java/org/springframework/integration/x/gemfire/JsonStringToObjectTransformerTests.java +++ b/extensions/spring-xd-extension-gemfire/src/test/java/org/springframework/integration/x/gemfire/JsonStringToObjectTransformerTests.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/config/GPFDistSinkOptionsMetadata.java b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/config/GPFDistSinkOptionsMetadata.java index 2b08bb313..cf590f098 100644 --- a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/config/GPFDistSinkOptionsMetadata.java +++ b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/config/GPFDistSinkOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/gpfdist/AbstractGPFDistMessageHandler.java b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/gpfdist/AbstractGPFDistMessageHandler.java index 60644ec9b..568829118 100644 --- a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/gpfdist/AbstractGPFDistMessageHandler.java +++ b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/gpfdist/AbstractGPFDistMessageHandler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/gpfdist/GPFDistCodec.java b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/gpfdist/GPFDistCodec.java index 233f97fd0..a809b9fe7 100644 --- a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/gpfdist/GPFDistCodec.java +++ b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/gpfdist/GPFDistCodec.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/gpfdist/GPFDistMessageHandler.java b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/gpfdist/GPFDistMessageHandler.java index b55610b81..1c2713bfe 100644 --- a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/gpfdist/GPFDistMessageHandler.java +++ b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/gpfdist/GPFDistMessageHandler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/gpfdist/GPFDistServer.java b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/gpfdist/GPFDistServer.java index 1fa338d23..a25b45d40 100644 --- a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/gpfdist/GPFDistServer.java +++ b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/gpfdist/GPFDistServer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/AbstractExternalTable.java b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/AbstractExternalTable.java index 5cbc1b0c6..3bccf691c 100644 --- a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/AbstractExternalTable.java +++ b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/AbstractExternalTable.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/ControlFile.java b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/ControlFile.java index 850d525e6..ea0fcb565 100644 --- a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/ControlFile.java +++ b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/ControlFile.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/ControlFileFactoryBean.java b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/ControlFileFactoryBean.java index d8d700981..721ed639b 100644 --- a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/ControlFileFactoryBean.java +++ b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/ControlFileFactoryBean.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/DefaultGreenplumLoad.java b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/DefaultGreenplumLoad.java index fc402f2a8..395ccad7a 100644 --- a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/DefaultGreenplumLoad.java +++ b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/DefaultGreenplumLoad.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/DefaultLoadService.java b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/DefaultLoadService.java index 278aa62ac..d79687446 100644 --- a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/DefaultLoadService.java +++ b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/DefaultLoadService.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/Format.java b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/Format.java index 7893ec666..c3524b5f7 100644 --- a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/Format.java +++ b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/Format.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/GreenplumDataSourceFactoryBean.java b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/GreenplumDataSourceFactoryBean.java index fe64b72df..73003bdfb 100644 --- a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/GreenplumDataSourceFactoryBean.java +++ b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/GreenplumDataSourceFactoryBean.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/GreenplumLoad.java b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/GreenplumLoad.java index 9d7c82715..ef0481a06 100644 --- a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/GreenplumLoad.java +++ b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/GreenplumLoad.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/JdbcCommands.java b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/JdbcCommands.java index 9731a2219..d80ee81c4 100644 --- a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/JdbcCommands.java +++ b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/JdbcCommands.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/LoadConfiguration.java b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/LoadConfiguration.java index bd9c9fd91..6edaf2fef 100644 --- a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/LoadConfiguration.java +++ b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/LoadConfiguration.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/LoadConfigurationFactoryBean.java b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/LoadConfigurationFactoryBean.java index d1b9a0023..38e4d0734 100644 --- a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/LoadConfigurationFactoryBean.java +++ b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/LoadConfigurationFactoryBean.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/LoadFactoryBean.java b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/LoadFactoryBean.java index 984e54e63..6110498b9 100644 --- a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/LoadFactoryBean.java +++ b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/LoadFactoryBean.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/LoadService.java b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/LoadService.java index ec824efa2..142a32b9f 100644 --- a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/LoadService.java +++ b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/LoadService.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/Mode.java b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/Mode.java index 2ff3f4d7e..4dad29925 100644 --- a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/Mode.java +++ b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/Mode.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/NetworkUtils.java b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/NetworkUtils.java index b51e8423a..3084fe540 100644 --- a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/NetworkUtils.java +++ b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/NetworkUtils.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/ReadableTable.java b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/ReadableTable.java index b14fa58a0..7fafcf288 100644 --- a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/ReadableTable.java +++ b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/ReadableTable.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/ReadableTableFactoryBean.java b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/ReadableTableFactoryBean.java index 7a6a8ce2c..38d7cac50 100644 --- a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/ReadableTableFactoryBean.java +++ b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/ReadableTableFactoryBean.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/RuntimeContext.java b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/RuntimeContext.java index 9edb49198..aded54bbe 100644 --- a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/RuntimeContext.java +++ b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/RuntimeContext.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/SegmentRejectType.java b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/SegmentRejectType.java index 06148c313..59353ba02 100644 --- a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/SegmentRejectType.java +++ b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/SegmentRejectType.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/SqlUtils.java b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/SqlUtils.java index 6001ac331..927a69663 100644 --- a/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/SqlUtils.java +++ b/extensions/spring-xd-extension-gpfdist/src/main/java/org/springframework/xd/greenplum/support/SqlUtils.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpfdist/src/test/java/org/springframework/xd/greenplum/AbstractLoadTests.java b/extensions/spring-xd-extension-gpfdist/src/test/java/org/springframework/xd/greenplum/AbstractLoadTests.java index f06fa64e6..388102dc8 100644 --- a/extensions/spring-xd-extension-gpfdist/src/test/java/org/springframework/xd/greenplum/AbstractLoadTests.java +++ b/extensions/spring-xd-extension-gpfdist/src/test/java/org/springframework/xd/greenplum/AbstractLoadTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpfdist/src/test/java/org/springframework/xd/greenplum/LoadIT.java b/extensions/spring-xd-extension-gpfdist/src/test/java/org/springframework/xd/greenplum/LoadIT.java index 65a78e279..2a0fd4d3a 100644 --- a/extensions/spring-xd-extension-gpfdist/src/test/java/org/springframework/xd/greenplum/LoadIT.java +++ b/extensions/spring-xd-extension-gpfdist/src/test/java/org/springframework/xd/greenplum/LoadIT.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpfdist/src/test/java/org/springframework/xd/greenplum/TestListenAddress.java b/extensions/spring-xd-extension-gpfdist/src/test/java/org/springframework/xd/greenplum/TestListenAddress.java index 5b92b11e6..d776c47b1 100644 --- a/extensions/spring-xd-extension-gpfdist/src/test/java/org/springframework/xd/greenplum/TestListenAddress.java +++ b/extensions/spring-xd-extension-gpfdist/src/test/java/org/springframework/xd/greenplum/TestListenAddress.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpfdist/src/test/java/org/springframework/xd/greenplum/TestUtils.java b/extensions/spring-xd-extension-gpfdist/src/test/java/org/springframework/xd/greenplum/TestUtils.java index d53d29b41..a031e9091 100644 --- a/extensions/spring-xd-extension-gpfdist/src/test/java/org/springframework/xd/greenplum/TestUtils.java +++ b/extensions/spring-xd-extension-gpfdist/src/test/java/org/springframework/xd/greenplum/TestUtils.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpfdist/src/test/java/org/springframework/xd/greenplum/support/ControlFileTests.java b/extensions/spring-xd-extension-gpfdist/src/test/java/org/springframework/xd/greenplum/support/ControlFileTests.java index f77ee5326..b14f554cc 100644 --- a/extensions/spring-xd-extension-gpfdist/src/test/java/org/springframework/xd/greenplum/support/ControlFileTests.java +++ b/extensions/spring-xd-extension-gpfdist/src/test/java/org/springframework/xd/greenplum/support/ControlFileTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpfdist/src/test/java/org/springframework/xd/greenplum/support/LoadConfigurationFactoryBeanTests.java b/extensions/spring-xd-extension-gpfdist/src/test/java/org/springframework/xd/greenplum/support/LoadConfigurationFactoryBeanTests.java index 67dc7778f..585274e13 100644 --- a/extensions/spring-xd-extension-gpfdist/src/test/java/org/springframework/xd/greenplum/support/LoadConfigurationFactoryBeanTests.java +++ b/extensions/spring-xd-extension-gpfdist/src/test/java/org/springframework/xd/greenplum/support/LoadConfigurationFactoryBeanTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpload/src/main/java/org/springframework/xd/gpload/GploadEnvironmentProvider.java b/extensions/spring-xd-extension-gpload/src/main/java/org/springframework/xd/gpload/GploadEnvironmentProvider.java index 0208ec4d9..5e785e8aa 100644 --- a/extensions/spring-xd-extension-gpload/src/main/java/org/springframework/xd/gpload/GploadEnvironmentProvider.java +++ b/extensions/spring-xd-extension-gpload/src/main/java/org/springframework/xd/gpload/GploadEnvironmentProvider.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpload/src/main/java/org/springframework/xd/gpload/GploadOptionsMetadata.java b/extensions/spring-xd-extension-gpload/src/main/java/org/springframework/xd/gpload/GploadOptionsMetadata.java index ff8f25d6d..4aae95134 100644 --- a/extensions/spring-xd-extension-gpload/src/main/java/org/springframework/xd/gpload/GploadOptionsMetadata.java +++ b/extensions/spring-xd-extension-gpload/src/main/java/org/springframework/xd/gpload/GploadOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-gpload/src/main/java/org/springframework/xd/gpload/GploadTasklet.java b/extensions/spring-xd-extension-gpload/src/main/java/org/springframework/xd/gpload/GploadTasklet.java index 6ed753712..286c11cdb 100644 --- a/extensions/spring-xd-extension-gpload/src/main/java/org/springframework/xd/gpload/GploadTasklet.java +++ b/extensions/spring-xd-extension-gpload/src/main/java/org/springframework/xd/gpload/GploadTasklet.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-header-enricher/src/test/java/org/springframework/xd/header/enricher/HeaderEnricherIntegrationTests.java b/extensions/spring-xd-extension-header-enricher/src/test/java/org/springframework/xd/header/enricher/HeaderEnricherIntegrationTests.java index 4f5ce8e08..2804bb5f3 100644 --- a/extensions/spring-xd-extension-header-enricher/src/test/java/org/springframework/xd/header/enricher/HeaderEnricherIntegrationTests.java +++ b/extensions/spring-xd-extension-header-enricher/src/test/java/org/springframework/xd/header/enricher/HeaderEnricherIntegrationTests.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-header-enricher/src/test/java/org/springframework/xd/header/enricher/HeaderEnricherModuleTests.java b/extensions/spring-xd-extension-header-enricher/src/test/java/org/springframework/xd/header/enricher/HeaderEnricherModuleTests.java index a689e0786..9f4ae0d88 100644 --- a/extensions/spring-xd-extension-header-enricher/src/test/java/org/springframework/xd/header/enricher/HeaderEnricherModuleTests.java +++ b/extensions/spring-xd-extension-header-enricher/src/test/java/org/springframework/xd/header/enricher/HeaderEnricherModuleTests.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-http/src/main/java/org/springframework/integration/x/http/NettyHttpInboundChannelAdapter.java b/extensions/spring-xd-extension-http/src/main/java/org/springframework/integration/x/http/NettyHttpInboundChannelAdapter.java index 84b907099..d970305e6 100644 --- a/extensions/spring-xd-extension-http/src/main/java/org/springframework/integration/x/http/NettyHttpInboundChannelAdapter.java +++ b/extensions/spring-xd-extension-http/src/main/java/org/springframework/integration/x/http/NettyHttpInboundChannelAdapter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-http/src/main/java/org/springframework/integration/x/http/NettyInboundMessageConverter.java b/extensions/spring-xd-extension-http/src/main/java/org/springframework/integration/x/http/NettyInboundMessageConverter.java index 1aab046c0..583b1a94a 100644 --- a/extensions/spring-xd-extension-http/src/main/java/org/springframework/integration/x/http/NettyInboundMessageConverter.java +++ b/extensions/spring-xd-extension-http/src/main/java/org/springframework/integration/x/http/NettyInboundMessageConverter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-http/src/main/java/org/springframework/xd/http/HttpClientProcessorOptionsMetadata.java b/extensions/spring-xd-extension-http/src/main/java/org/springframework/xd/http/HttpClientProcessorOptionsMetadata.java index 109cdee05..15687f9fa 100644 --- a/extensions/spring-xd-extension-http/src/main/java/org/springframework/xd/http/HttpClientProcessorOptionsMetadata.java +++ b/extensions/spring-xd-extension-http/src/main/java/org/springframework/xd/http/HttpClientProcessorOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-http/src/test/java/org/springframework/integration/x/http/NettyHttpInboundChannelAdapterTests.java b/extensions/spring-xd-extension-http/src/test/java/org/springframework/integration/x/http/NettyHttpInboundChannelAdapterTests.java index 75054cb94..8091e7f8e 100644 --- a/extensions/spring-xd-extension-http/src/test/java/org/springframework/integration/x/http/NettyHttpInboundChannelAdapterTests.java +++ b/extensions/spring-xd-extension-http/src/test/java/org/springframework/integration/x/http/NettyHttpInboundChannelAdapterTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/AbstractImportToJdbcOptionsMetadata.java b/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/AbstractImportToJdbcOptionsMetadata.java index 1fc814264..b604992e6 100644 --- a/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/AbstractImportToJdbcOptionsMetadata.java +++ b/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/AbstractImportToJdbcOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/FileJdbcJobOptionsMetadata.java b/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/FileJdbcJobOptionsMetadata.java index 30afab16d..845e14fe2 100644 --- a/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/FileJdbcJobOptionsMetadata.java +++ b/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/FileJdbcJobOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/JdbcConnectionMixin.java b/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/JdbcConnectionMixin.java index b01228d93..aaeb48f6d 100644 --- a/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/JdbcConnectionMixin.java +++ b/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/JdbcConnectionMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/JdbcConnectionPoolMixin.java b/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/JdbcConnectionPoolMixin.java index f1347934c..7fe8ba75e 100644 --- a/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/JdbcConnectionPoolMixin.java +++ b/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/JdbcConnectionPoolMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/JdbcHdfsOptionsMetadata.java b/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/JdbcHdfsOptionsMetadata.java index 3efa34c68..e180e5221 100644 --- a/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/JdbcHdfsOptionsMetadata.java +++ b/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/JdbcHdfsOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/JdbcMessagePayloadTransformer.java b/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/JdbcMessagePayloadTransformer.java index f44277a5c..55d31141a 100644 --- a/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/JdbcMessagePayloadTransformer.java +++ b/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/JdbcMessagePayloadTransformer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/JdbcSinkModuleOptionsMetadata.java b/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/JdbcSinkModuleOptionsMetadata.java index 633656c86..413704a71 100644 --- a/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/JdbcSinkModuleOptionsMetadata.java +++ b/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/JdbcSinkModuleOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/JdbcSourceModuleOptionsMetadata.java b/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/JdbcSourceModuleOptionsMetadata.java index 42694686d..9c8bbd3d3 100644 --- a/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/JdbcSourceModuleOptionsMetadata.java +++ b/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/JdbcSourceModuleOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/NamedColumnJdbcBatchItemWriter.java b/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/NamedColumnJdbcBatchItemWriter.java index 95fc8f817..9a9de3444 100644 --- a/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/NamedColumnJdbcBatchItemWriter.java +++ b/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/NamedColumnJdbcBatchItemWriter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/NamedColumnJdbcItemReader.java b/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/NamedColumnJdbcItemReader.java index 604d42a8d..48a54a142 100644 --- a/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/NamedColumnJdbcItemReader.java +++ b/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/NamedColumnJdbcItemReader.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/NamedColumnJdbcItemReaderFactory.java b/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/NamedColumnJdbcItemReaderFactory.java index ae0469442..1a4ad31b0 100644 --- a/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/NamedColumnJdbcItemReaderFactory.java +++ b/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/NamedColumnJdbcItemReaderFactory.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/ResourcesIntoJdbcJobModuleOptionsMetadata.java b/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/ResourcesIntoJdbcJobModuleOptionsMetadata.java index 741f04c30..e156cb70a 100644 --- a/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/ResourcesIntoJdbcJobModuleOptionsMetadata.java +++ b/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/ResourcesIntoJdbcJobModuleOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/SingleTableDatabaseInitializer.java b/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/SingleTableDatabaseInitializer.java index 4593cf606..6507a3aa9 100644 --- a/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/SingleTableDatabaseInitializer.java +++ b/extensions/spring-xd-extension-jdbc/src/main/java/org/springframework/xd/jdbc/SingleTableDatabaseInitializer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-jdbc/src/test/java/org/springframework/xd/jdbc/JdbcMessagePayloadTransformerTests.java b/extensions/spring-xd-extension-jdbc/src/test/java/org/springframework/xd/jdbc/JdbcMessagePayloadTransformerTests.java index ebaa4bbc7..10b2062a2 100644 --- a/extensions/spring-xd-extension-jdbc/src/test/java/org/springframework/xd/jdbc/JdbcMessagePayloadTransformerTests.java +++ b/extensions/spring-xd-extension-jdbc/src/test/java/org/springframework/xd/jdbc/JdbcMessagePayloadTransformerTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-jdbc/src/test/java/org/springframework/xd/jdbc/NamedColumnJdbcItemReaderFactoryTests.java b/extensions/spring-xd-extension-jdbc/src/test/java/org/springframework/xd/jdbc/NamedColumnJdbcItemReaderFactoryTests.java index b724ff4e3..4e6c77a3e 100644 --- a/extensions/spring-xd-extension-jdbc/src/test/java/org/springframework/xd/jdbc/NamedColumnJdbcItemReaderFactoryTests.java +++ b/extensions/spring-xd-extension-jdbc/src/test/java/org/springframework/xd/jdbc/NamedColumnJdbcItemReaderFactoryTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-jdbc/src/test/java/org/springframework/xd/jdbc/SingleTableDatabaseInitializerTests.java b/extensions/spring-xd-extension-jdbc/src/test/java/org/springframework/xd/jdbc/SingleTableDatabaseInitializerTests.java index c6b5ed7e4..f7eec4c59 100644 --- a/extensions/spring-xd-extension-jdbc/src/test/java/org/springframework/xd/jdbc/SingleTableDatabaseInitializerTests.java +++ b/extensions/spring-xd-extension-jdbc/src/test/java/org/springframework/xd/jdbc/SingleTableDatabaseInitializerTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/AutoOffsetResetStrategy.java b/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/AutoOffsetResetStrategy.java index a98d242f8..e307b8396 100644 --- a/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/AutoOffsetResetStrategy.java +++ b/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/AutoOffsetResetStrategy.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/InitialOffsetsFactoryBean.java b/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/InitialOffsetsFactoryBean.java index ec8c2075d..d7ee880a4 100644 --- a/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/InitialOffsetsFactoryBean.java +++ b/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/InitialOffsetsFactoryBean.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaConsumerOptionsMixin.java b/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaConsumerOptionsMixin.java index da7d5b63c..d5c8a5123 100644 --- a/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaConsumerOptionsMixin.java +++ b/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaConsumerOptionsMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaMessageTransformer.java b/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaMessageTransformer.java index ed79474b8..07866f451 100644 --- a/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaMessageTransformer.java +++ b/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaMessageTransformer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaOffsetTopicOptionsMixin.java b/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaOffsetTopicOptionsMixin.java index 60c8fa38b..8bfdce6cf 100644 --- a/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaOffsetTopicOptionsMixin.java +++ b/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaOffsetTopicOptionsMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaPartitionAllocator.java b/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaPartitionAllocator.java index 9420ff232..ac8bf0e2d 100644 --- a/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaPartitionAllocator.java +++ b/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaPartitionAllocator.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaProducerOptionsMixin.java b/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaProducerOptionsMixin.java index f0927ca27..ebe29b06d 100644 --- a/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaProducerOptionsMixin.java +++ b/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaProducerOptionsMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaSinkModuleOptionsMetadata.java b/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaSinkModuleOptionsMetadata.java index cec38898f..65d61c841 100644 --- a/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaSinkModuleOptionsMetadata.java +++ b/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaSinkModuleOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaSourceModuleOptionsMetadata.java b/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaSourceModuleOptionsMetadata.java index 38f8e44ed..284768fcb 100644 --- a/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaSourceModuleOptionsMetadata.java +++ b/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaSourceModuleOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaZKOptionMixin.java b/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaZKOptionMixin.java index bc525da1c..3e795a83a 100644 --- a/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaZKOptionMixin.java +++ b/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/KafkaZKOptionMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/NamespaceDelegatingMetadataStore.java b/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/NamespaceDelegatingMetadataStore.java index a6aae219d..d1499a220 100644 --- a/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/NamespaceDelegatingMetadataStore.java +++ b/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/NamespaceDelegatingMetadataStore.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/WindowingOffsetManager.java b/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/WindowingOffsetManager.java index 5b255e4ba..bd7835d6c 100644 --- a/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/WindowingOffsetManager.java +++ b/extensions/spring-xd-extension-kafka/src/main/java/org/springframework/integration/x/kafka/WindowingOffsetManager.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-mail/src/main/java/org/springframework/xd/mail/JavaMailPropertiesFactoryBean.java b/extensions/spring-xd-extension-mail/src/main/java/org/springframework/xd/mail/JavaMailPropertiesFactoryBean.java index 1ff65e55c..170311b29 100644 --- a/extensions/spring-xd-extension-mail/src/main/java/org/springframework/xd/mail/JavaMailPropertiesFactoryBean.java +++ b/extensions/spring-xd-extension-mail/src/main/java/org/springframework/xd/mail/JavaMailPropertiesFactoryBean.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-mail/src/main/java/org/springframework/xd/mail/MailProtocol.java b/extensions/spring-xd-extension-mail/src/main/java/org/springframework/xd/mail/MailProtocol.java index 1d45627cf..07e17b2e2 100644 --- a/extensions/spring-xd-extension-mail/src/main/java/org/springframework/xd/mail/MailProtocol.java +++ b/extensions/spring-xd-extension-mail/src/main/java/org/springframework/xd/mail/MailProtocol.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-mail/src/main/java/org/springframework/xd/mail/MailServerMixin.java b/extensions/spring-xd-extension-mail/src/main/java/org/springframework/xd/mail/MailServerMixin.java index 3a6a0f0ee..9dd3671c6 100644 --- a/extensions/spring-xd-extension-mail/src/main/java/org/springframework/xd/mail/MailServerMixin.java +++ b/extensions/spring-xd-extension-mail/src/main/java/org/springframework/xd/mail/MailServerMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-mail/src/main/java/org/springframework/xd/mail/MailSinkOptionsMetadata.java b/extensions/spring-xd-extension-mail/src/main/java/org/springframework/xd/mail/MailSinkOptionsMetadata.java index 2228e9131..daf9f46c5 100644 --- a/extensions/spring-xd-extension-mail/src/main/java/org/springframework/xd/mail/MailSinkOptionsMetadata.java +++ b/extensions/spring-xd-extension-mail/src/main/java/org/springframework/xd/mail/MailSinkOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-mail/src/main/java/org/springframework/xd/mail/MailSourceOptionsMetadata.java b/extensions/spring-xd-extension-mail/src/main/java/org/springframework/xd/mail/MailSourceOptionsMetadata.java index e11a9f152..344f6a2cd 100644 --- a/extensions/spring-xd-extension-mail/src/main/java/org/springframework/xd/mail/MailSourceOptionsMetadata.java +++ b/extensions/spring-xd-extension-mail/src/main/java/org/springframework/xd/mail/MailSourceOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-mongodb/src/main/java/org/springframework/xd/mongodb/FieldSetConverter.java b/extensions/spring-xd-extension-mongodb/src/main/java/org/springframework/xd/mongodb/FieldSetConverter.java index cc50c745e..60163b8cb 100644 --- a/extensions/spring-xd-extension-mongodb/src/main/java/org/springframework/xd/mongodb/FieldSetConverter.java +++ b/extensions/spring-xd-extension-mongodb/src/main/java/org/springframework/xd/mongodb/FieldSetConverter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-mongodb/src/main/java/org/springframework/xd/mongodb/TupleWriteConverter.java b/extensions/spring-xd-extension-mongodb/src/main/java/org/springframework/xd/mongodb/TupleWriteConverter.java index bfb21305e..b4722b0af 100644 --- a/extensions/spring-xd-extension-mongodb/src/main/java/org/springframework/xd/mongodb/TupleWriteConverter.java +++ b/extensions/spring-xd-extension-mongodb/src/main/java/org/springframework/xd/mongodb/TupleWriteConverter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-process/src/main/java/org/springframework/xd/extension/process/DelimitedStringToMapPropertyEditor.java b/extensions/spring-xd-extension-process/src/main/java/org/springframework/xd/extension/process/DelimitedStringToMapPropertyEditor.java index 57e2a3776..571b9a056 100644 --- a/extensions/spring-xd-extension-process/src/main/java/org/springframework/xd/extension/process/DelimitedStringToMapPropertyEditor.java +++ b/extensions/spring-xd-extension-process/src/main/java/org/springframework/xd/extension/process/DelimitedStringToMapPropertyEditor.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-process/src/main/java/org/springframework/xd/extension/process/ShellCommandProcessor.java b/extensions/spring-xd-extension-process/src/main/java/org/springframework/xd/extension/process/ShellCommandProcessor.java index 0e2aa0f61..38b1f45e1 100644 --- a/extensions/spring-xd-extension-process/src/main/java/org/springframework/xd/extension/process/ShellCommandProcessor.java +++ b/extensions/spring-xd-extension-process/src/main/java/org/springframework/xd/extension/process/ShellCommandProcessor.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-process/src/main/java/org/springframework/xd/extension/process/ShellModuleOptionsMetadata.java b/extensions/spring-xd-extension-process/src/main/java/org/springframework/xd/extension/process/ShellModuleOptionsMetadata.java index 7cee91b5f..a0b1ce893 100644 --- a/extensions/spring-xd-extension-process/src/main/java/org/springframework/xd/extension/process/ShellModuleOptionsMetadata.java +++ b/extensions/spring-xd-extension-process/src/main/java/org/springframework/xd/extension/process/ShellModuleOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-process/src/main/java/org/springframework/xd/extension/process/ShellWordsParser.java b/extensions/spring-xd-extension-process/src/main/java/org/springframework/xd/extension/process/ShellWordsParser.java index 1f2417f1f..0b80c0b43 100644 --- a/extensions/spring-xd-extension-process/src/main/java/org/springframework/xd/extension/process/ShellWordsParser.java +++ b/extensions/spring-xd-extension-process/src/main/java/org/springframework/xd/extension/process/ShellWordsParser.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-process/src/test/java/org/springframework/xd/extension/process/PythonAvailableRule.java b/extensions/spring-xd-extension-process/src/test/java/org/springframework/xd/extension/process/PythonAvailableRule.java index db82a795d..60c9481f5 100644 --- a/extensions/spring-xd-extension-process/src/test/java/org/springframework/xd/extension/process/PythonAvailableRule.java +++ b/extensions/spring-xd-extension-process/src/test/java/org/springframework/xd/extension/process/PythonAvailableRule.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-process/src/test/java/org/springframework/xd/extension/process/ShellCommandProcessorTests.java b/extensions/spring-xd-extension-process/src/test/java/org/springframework/xd/extension/process/ShellCommandProcessorTests.java index 2e207731e..94f2a4406 100644 --- a/extensions/spring-xd-extension-process/src/test/java/org/springframework/xd/extension/process/ShellCommandProcessorTests.java +++ b/extensions/spring-xd-extension-process/src/test/java/org/springframework/xd/extension/process/ShellCommandProcessorTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-process/src/test/java/org/springframework/xd/extension/process/ShellWordsParserTest.java b/extensions/spring-xd-extension-process/src/test/java/org/springframework/xd/extension/process/ShellWordsParserTest.java index 27f19630e..0a482a5cf 100644 --- a/extensions/spring-xd-extension-process/src/test/java/org/springframework/xd/extension/process/ShellWordsParserTest.java +++ b/extensions/spring-xd-extension-process/src/test/java/org/springframework/xd/extension/process/ShellWordsParserTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/config/ReactorNamespaceHandler.java b/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/config/ReactorNamespaceHandler.java index 6ec93a121..4e6e8a20d 100644 --- a/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/config/ReactorNamespaceHandler.java +++ b/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/config/ReactorNamespaceHandler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/config/SyslogInboundChannelAdapterParser.java b/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/config/SyslogInboundChannelAdapterParser.java index 6aec186c7..4387273cf 100644 --- a/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/config/SyslogInboundChannelAdapterParser.java +++ b/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/config/SyslogInboundChannelAdapterParser.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/net/ReactorNetSourceOptionsMetadata.java b/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/net/ReactorNetSourceOptionsMetadata.java index a5e00e850..b4b78a205 100644 --- a/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/net/ReactorNetSourceOptionsMetadata.java +++ b/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/net/ReactorNetSourceOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/net/ReactorPeerFactoryBean.java b/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/net/ReactorPeerFactoryBean.java index ea0a88998..d252f6d18 100644 --- a/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/net/ReactorPeerFactoryBean.java +++ b/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/net/ReactorPeerFactoryBean.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/net/ReactorPeerInboundChannelAdapter.java b/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/net/ReactorPeerInboundChannelAdapter.java index 5de7c9415..581db01de 100644 --- a/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/net/ReactorPeerInboundChannelAdapter.java +++ b/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/net/ReactorPeerInboundChannelAdapter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/net/ReactorPeerInboundChannelAdapterConfiguration.java b/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/net/ReactorPeerInboundChannelAdapterConfiguration.java index 8aa42fdc3..3f0fb51bc 100644 --- a/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/net/ReactorPeerInboundChannelAdapterConfiguration.java +++ b/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/net/ReactorPeerInboundChannelAdapterConfiguration.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/syslog/SyslogInboundChannelAdapter.java b/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/syslog/SyslogInboundChannelAdapter.java index ef6d43762..9e82deac7 100644 --- a/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/syslog/SyslogInboundChannelAdapter.java +++ b/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/syslog/SyslogInboundChannelAdapter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/syslog/SyslogInboundChannelAdapterConfiguration.java b/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/syslog/SyslogInboundChannelAdapterConfiguration.java index 1bc8fd62e..1fdf744ff 100644 --- a/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/syslog/SyslogInboundChannelAdapterConfiguration.java +++ b/extensions/spring-xd-extension-reactor/src/main/java/org/springframework/xd/integration/reactor/syslog/SyslogInboundChannelAdapterConfiguration.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-reactor/src/test/java/org/springframework/xd/integration/reactor/NetServerInboundChannelAdapterIntegrationTests.java b/extensions/spring-xd-extension-reactor/src/test/java/org/springframework/xd/integration/reactor/NetServerInboundChannelAdapterIntegrationTests.java index 763a253c9..688fd29dd 100644 --- a/extensions/spring-xd-extension-reactor/src/test/java/org/springframework/xd/integration/reactor/NetServerInboundChannelAdapterIntegrationTests.java +++ b/extensions/spring-xd-extension-reactor/src/test/java/org/springframework/xd/integration/reactor/NetServerInboundChannelAdapterIntegrationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-reactor/src/test/java/org/springframework/xd/integration/reactor/SyslogInboundChannelAdapterIntegrationTests.java b/extensions/spring-xd-extension-reactor/src/test/java/org/springframework/xd/integration/reactor/SyslogInboundChannelAdapterIntegrationTests.java index 0fd852c20..8ffe8b5ea 100644 --- a/extensions/spring-xd-extension-reactor/src/test/java/org/springframework/xd/integration/reactor/SyslogInboundChannelAdapterIntegrationTests.java +++ b/extensions/spring-xd-extension-reactor/src/test/java/org/springframework/xd/integration/reactor/SyslogInboundChannelAdapterIntegrationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-reactor/src/test/java/org/springframework/xd/integration/reactor/TestMessageHandler.java b/extensions/spring-xd-extension-reactor/src/test/java/org/springframework/xd/integration/reactor/TestMessageHandler.java index 5f557c61d..12784b059 100644 --- a/extensions/spring-xd-extension-reactor/src/test/java/org/springframework/xd/integration/reactor/TestMessageHandler.java +++ b/extensions/spring-xd-extension-reactor/src/test/java/org/springframework/xd/integration/reactor/TestMessageHandler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-redis/src/main/java/org/springframework/xd/redis/RedisSinkConfiguration.java b/extensions/spring-xd-extension-redis/src/main/java/org/springframework/xd/redis/RedisSinkConfiguration.java index 05ae98f42..86160c6ae 100644 --- a/extensions/spring-xd-extension-redis/src/main/java/org/springframework/xd/redis/RedisSinkConfiguration.java +++ b/extensions/spring-xd-extension-redis/src/main/java/org/springframework/xd/redis/RedisSinkConfiguration.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-script/src/main/java/org/springframework/xd/extension/script/ScriptModulePropertiesFactoryBean.java b/extensions/spring-xd-extension-script/src/main/java/org/springframework/xd/extension/script/ScriptModulePropertiesFactoryBean.java index 6d3052c19..a61ff69bb 100644 --- a/extensions/spring-xd-extension-script/src/main/java/org/springframework/xd/extension/script/ScriptModulePropertiesFactoryBean.java +++ b/extensions/spring-xd-extension-script/src/main/java/org/springframework/xd/extension/script/ScriptModulePropertiesFactoryBean.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-script/src/test/java/org/springframework/xd/extension/script/ScriptModulePropertiesFactoryBeanTest.java b/extensions/spring-xd-extension-script/src/test/java/org/springframework/xd/extension/script/ScriptModulePropertiesFactoryBeanTest.java index e9f5ce054..8bbdb8d6b 100644 --- a/extensions/spring-xd-extension-script/src/test/java/org/springframework/xd/extension/script/ScriptModulePropertiesFactoryBeanTest.java +++ b/extensions/spring-xd-extension-script/src/test/java/org/springframework/xd/extension/script/ScriptModulePropertiesFactoryBeanTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-spark/src/main/java/org/springframework/xd/spark/SparkAppOptionsMetadata.java b/extensions/spring-xd-extension-spark/src/main/java/org/springframework/xd/spark/SparkAppOptionsMetadata.java index bb7853945..a0aea122e 100644 --- a/extensions/spring-xd-extension-spark/src/main/java/org/springframework/xd/spark/SparkAppOptionsMetadata.java +++ b/extensions/spring-xd-extension-spark/src/main/java/org/springframework/xd/spark/SparkAppOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-spark/src/main/java/org/springframework/xd/spark/package-info.java b/extensions/spring-xd-extension-spark/src/main/java/org/springframework/xd/spark/package-info.java index f3ca1597c..d365e03fe 100644 --- a/extensions/spring-xd-extension-spark/src/main/java/org/springframework/xd/spark/package-info.java +++ b/extensions/spring-xd-extension-spark/src/main/java/org/springframework/xd/spark/package-info.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-spark/src/main/java/org/springframework/xd/spark/tasklet/SparkTasklet.java b/extensions/spring-xd-extension-spark/src/main/java/org/springframework/xd/spark/tasklet/SparkTasklet.java index 35ff2a41f..fcde2e3aa 100644 --- a/extensions/spring-xd-extension-spark/src/main/java/org/springframework/xd/spark/tasklet/SparkTasklet.java +++ b/extensions/spring-xd-extension-spark/src/main/java/org/springframework/xd/spark/tasklet/SparkTasklet.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-spark/src/main/java/org/springframework/xd/spark/tasklet/package-info.java b/extensions/spring-xd-extension-spark/src/main/java/org/springframework/xd/spark/tasklet/package-info.java index 565c43e2a..db9fe0d96 100644 --- a/extensions/spring-xd-extension-spark/src/main/java/org/springframework/xd/spark/tasklet/package-info.java +++ b/extensions/spring-xd-extension-spark/src/main/java/org/springframework/xd/spark/tasklet/package-info.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-splunk/src/main/java/org/springframework/integration/x/splunk/SplunkTransformer.java b/extensions/spring-xd-extension-splunk/src/main/java/org/springframework/integration/x/splunk/SplunkTransformer.java index d4d329aa4..e00b5e6ff 100644 --- a/extensions/spring-xd-extension-splunk/src/main/java/org/springframework/integration/x/splunk/SplunkTransformer.java +++ b/extensions/spring-xd-extension-splunk/src/main/java/org/springframework/integration/x/splunk/SplunkTransformer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-splunk/src/main/java/org/springframework/xd/splunk/SplunkSinkOptionsMetadata.java b/extensions/spring-xd-extension-splunk/src/main/java/org/springframework/xd/splunk/SplunkSinkOptionsMetadata.java index 97b4920dd..e548cb20c 100644 --- a/extensions/spring-xd-extension-splunk/src/main/java/org/springframework/xd/splunk/SplunkSinkOptionsMetadata.java +++ b/extensions/spring-xd-extension-splunk/src/main/java/org/springframework/xd/splunk/SplunkSinkOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-sqoop/src/main/java/org/springframework/xd/sqoop/SqoopEnvironmentProvider.java b/extensions/spring-xd-extension-sqoop/src/main/java/org/springframework/xd/sqoop/SqoopEnvironmentProvider.java index 52dfa66b1..050aef780 100644 --- a/extensions/spring-xd-extension-sqoop/src/main/java/org/springframework/xd/sqoop/SqoopEnvironmentProvider.java +++ b/extensions/spring-xd-extension-sqoop/src/main/java/org/springframework/xd/sqoop/SqoopEnvironmentProvider.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-sqoop/src/main/java/org/springframework/xd/sqoop/SqoopOptionsMetadata.java b/extensions/spring-xd-extension-sqoop/src/main/java/org/springframework/xd/sqoop/SqoopOptionsMetadata.java index 1c53dbce9..5d1163abf 100644 --- a/extensions/spring-xd-extension-sqoop/src/main/java/org/springframework/xd/sqoop/SqoopOptionsMetadata.java +++ b/extensions/spring-xd-extension-sqoop/src/main/java/org/springframework/xd/sqoop/SqoopOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-sqoop/src/main/java/org/springframework/xd/sqoop/SqoopRunner.java b/extensions/spring-xd-extension-sqoop/src/main/java/org/springframework/xd/sqoop/SqoopRunner.java index b119ef770..3192fa01c 100644 --- a/extensions/spring-xd-extension-sqoop/src/main/java/org/springframework/xd/sqoop/SqoopRunner.java +++ b/extensions/spring-xd-extension-sqoop/src/main/java/org/springframework/xd/sqoop/SqoopRunner.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-sqoop/src/main/java/org/springframework/xd/sqoop/SqoopTasklet.java b/extensions/spring-xd-extension-sqoop/src/main/java/org/springframework/xd/sqoop/SqoopTasklet.java index 586400b80..ada224d1b 100644 --- a/extensions/spring-xd-extension-sqoop/src/main/java/org/springframework/xd/sqoop/SqoopTasklet.java +++ b/extensions/spring-xd-extension-sqoop/src/main/java/org/springframework/xd/sqoop/SqoopTasklet.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-sqoop/src/main/java/org/springframework/xd/sqoop/package-info.java b/extensions/spring-xd-extension-sqoop/src/main/java/org/springframework/xd/sqoop/package-info.java index f250ee1e0..ac4452b7c 100644 --- a/extensions/spring-xd-extension-sqoop/src/main/java/org/springframework/xd/sqoop/package-info.java +++ b/extensions/spring-xd-extension-sqoop/src/main/java/org/springframework/xd/sqoop/package-info.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-syslog/src/main/java/org/springframework/xd/syslog/SyslogSourceOptionsMetadata.java b/extensions/spring-xd-extension-syslog/src/main/java/org/springframework/xd/syslog/SyslogSourceOptionsMetadata.java index d045a73d4..d626ae5a3 100644 --- a/extensions/spring-xd-extension-syslog/src/main/java/org/springframework/xd/syslog/SyslogSourceOptionsMetadata.java +++ b/extensions/spring-xd-extension-syslog/src/main/java/org/springframework/xd/syslog/SyslogSourceOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-syslog/src/main/java/org/springframework/xd/syslog/SyslogTcpSourceOptionsMetadata.java b/extensions/spring-xd-extension-syslog/src/main/java/org/springframework/xd/syslog/SyslogTcpSourceOptionsMetadata.java index 101aaa9b2..f4e4b4382 100644 --- a/extensions/spring-xd-extension-syslog/src/main/java/org/springframework/xd/syslog/SyslogTcpSourceOptionsMetadata.java +++ b/extensions/spring-xd-extension-syslog/src/main/java/org/springframework/xd/syslog/SyslogTcpSourceOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-tcp/src/main/java/org/springframework/xd/tcp/AbstractTcpConnectionFactoryOptionsMetadata.java b/extensions/spring-xd-extension-tcp/src/main/java/org/springframework/xd/tcp/AbstractTcpConnectionFactoryOptionsMetadata.java index 16b156faf..6ca19b6cc 100644 --- a/extensions/spring-xd-extension-tcp/src/main/java/org/springframework/xd/tcp/AbstractTcpConnectionFactoryOptionsMetadata.java +++ b/extensions/spring-xd-extension-tcp/src/main/java/org/springframework/xd/tcp/AbstractTcpConnectionFactoryOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-tcp/src/main/java/org/springframework/xd/tcp/ClientTcpConnectionFactoryOptionsMetadataMixin.java b/extensions/spring-xd-extension-tcp/src/main/java/org/springframework/xd/tcp/ClientTcpConnectionFactoryOptionsMetadataMixin.java index c90051167..88f42f3dc 100644 --- a/extensions/spring-xd-extension-tcp/src/main/java/org/springframework/xd/tcp/ClientTcpConnectionFactoryOptionsMetadataMixin.java +++ b/extensions/spring-xd-extension-tcp/src/main/java/org/springframework/xd/tcp/ClientTcpConnectionFactoryOptionsMetadataMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-tcp/src/main/java/org/springframework/xd/tcp/ServerTcpConnectionFactoryOptionsMetadataMixin.java b/extensions/spring-xd-extension-tcp/src/main/java/org/springframework/xd/tcp/ServerTcpConnectionFactoryOptionsMetadataMixin.java index e70a28e1f..0a3f5735e 100644 --- a/extensions/spring-xd-extension-tcp/src/main/java/org/springframework/xd/tcp/ServerTcpConnectionFactoryOptionsMetadataMixin.java +++ b/extensions/spring-xd-extension-tcp/src/main/java/org/springframework/xd/tcp/ServerTcpConnectionFactoryOptionsMetadataMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-tcp/src/main/java/org/springframework/xd/tcp/TcpClientSourceOptionsMetadata.java b/extensions/spring-xd-extension-tcp/src/main/java/org/springframework/xd/tcp/TcpClientSourceOptionsMetadata.java index b34def0e3..5b5ab909e 100644 --- a/extensions/spring-xd-extension-tcp/src/main/java/org/springframework/xd/tcp/TcpClientSourceOptionsMetadata.java +++ b/extensions/spring-xd-extension-tcp/src/main/java/org/springframework/xd/tcp/TcpClientSourceOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-tcp/src/main/java/org/springframework/xd/tcp/TcpSinkOptionsMetadata.java b/extensions/spring-xd-extension-tcp/src/main/java/org/springframework/xd/tcp/TcpSinkOptionsMetadata.java index 3ce51b915..7615e69e7 100644 --- a/extensions/spring-xd-extension-tcp/src/main/java/org/springframework/xd/tcp/TcpSinkOptionsMetadata.java +++ b/extensions/spring-xd-extension-tcp/src/main/java/org/springframework/xd/tcp/TcpSinkOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-tcp/src/main/java/org/springframework/xd/tcp/TcpSourceOptionsMetadata.java b/extensions/spring-xd-extension-tcp/src/main/java/org/springframework/xd/tcp/TcpSourceOptionsMetadata.java index 2cf8e103f..ba0061a4b 100644 --- a/extensions/spring-xd-extension-tcp/src/main/java/org/springframework/xd/tcp/TcpSourceOptionsMetadata.java +++ b/extensions/spring-xd-extension-tcp/src/main/java/org/springframework/xd/tcp/TcpSourceOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-throughput/src/main/java/org/springframework/xd/integration/throughput/ThroughputSamplerMessageHandler.java b/extensions/spring-xd-extension-throughput/src/main/java/org/springframework/xd/integration/throughput/ThroughputSamplerMessageHandler.java index c5f29edf2..6030f37f3 100644 --- a/extensions/spring-xd-extension-throughput/src/main/java/org/springframework/xd/integration/throughput/ThroughputSamplerMessageHandler.java +++ b/extensions/spring-xd-extension-throughput/src/main/java/org/springframework/xd/integration/throughput/ThroughputSamplerMessageHandler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-throughput/src/main/java/org/springframework/xd/integration/throughput/ThroughputSamplerOptionsMetadata.java b/extensions/spring-xd-extension-throughput/src/main/java/org/springframework/xd/integration/throughput/ThroughputSamplerOptionsMetadata.java index fcc2a7110..2f8e0cbd8 100644 --- a/extensions/spring-xd-extension-throughput/src/main/java/org/springframework/xd/integration/throughput/ThroughputSamplerOptionsMetadata.java +++ b/extensions/spring-xd-extension-throughput/src/main/java/org/springframework/xd/integration/throughput/ThroughputSamplerOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-throughput/src/test/java/org/springframework/xd/integration/throughput/ThroughputSampleIntegrationTests.java b/extensions/spring-xd-extension-throughput/src/test/java/org/springframework/xd/integration/throughput/ThroughputSampleIntegrationTests.java index 63bc1b0ca..9ee8ce12e 100644 --- a/extensions/spring-xd-extension-throughput/src/test/java/org/springframework/xd/integration/throughput/ThroughputSampleIntegrationTests.java +++ b/extensions/spring-xd-extension-throughput/src/test/java/org/springframework/xd/integration/throughput/ThroughputSampleIntegrationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-throughput/src/test/resources/log4j.properties b/extensions/spring-xd-extension-throughput/src/test/resources/log4j.properties index 5f6885bf7..0ccc95940 100644 --- a/extensions/spring-xd-extension-throughput/src/test/resources/log4j.properties +++ b/extensions/spring-xd-extension-throughput/src/test/resources/log4j.properties @@ -5,7 +5,7 @@ # you may not use this file except in compliance with the License. # You may obtain a copy of the License at # -# http://www.apache.org/licenses/LICENSE-2.0 +# https://www.apache.org/licenses/LICENSE-2.0 # # Unless required by applicable law or agreed to in writing, software # distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-twitter/src/main/java/org/springframework/integration/x/twitter/AbstractTwitterInboundChannelAdapter.java b/extensions/spring-xd-extension-twitter/src/main/java/org/springframework/integration/x/twitter/AbstractTwitterInboundChannelAdapter.java index a77d93f8b..48ae735bd 100644 --- a/extensions/spring-xd-extension-twitter/src/main/java/org/springframework/integration/x/twitter/AbstractTwitterInboundChannelAdapter.java +++ b/extensions/spring-xd-extension-twitter/src/main/java/org/springframework/integration/x/twitter/AbstractTwitterInboundChannelAdapter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-twitter/src/main/java/org/springframework/integration/x/twitter/TwitterMixin.java b/extensions/spring-xd-extension-twitter/src/main/java/org/springframework/integration/x/twitter/TwitterMixin.java index 05f36caf1..956c9c200 100644 --- a/extensions/spring-xd-extension-twitter/src/main/java/org/springframework/integration/x/twitter/TwitterMixin.java +++ b/extensions/spring-xd-extension-twitter/src/main/java/org/springframework/integration/x/twitter/TwitterMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-twitter/src/main/java/org/springframework/integration/x/twitter/TwitterSearchChannelAdapter.java b/extensions/spring-xd-extension-twitter/src/main/java/org/springframework/integration/x/twitter/TwitterSearchChannelAdapter.java index 08213be4b..10e1c13c0 100644 --- a/extensions/spring-xd-extension-twitter/src/main/java/org/springframework/integration/x/twitter/TwitterSearchChannelAdapter.java +++ b/extensions/spring-xd-extension-twitter/src/main/java/org/springframework/integration/x/twitter/TwitterSearchChannelAdapter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-twitter/src/main/java/org/springframework/integration/x/twitter/TwitterSearchOptionsMetadata.java b/extensions/spring-xd-extension-twitter/src/main/java/org/springframework/integration/x/twitter/TwitterSearchOptionsMetadata.java index dd6ec8b84..8b2a0d622 100644 --- a/extensions/spring-xd-extension-twitter/src/main/java/org/springframework/integration/x/twitter/TwitterSearchOptionsMetadata.java +++ b/extensions/spring-xd-extension-twitter/src/main/java/org/springframework/integration/x/twitter/TwitterSearchOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-twitter/src/main/java/org/springframework/integration/x/twitter/TwitterStreamChannelAdapter.java b/extensions/spring-xd-extension-twitter/src/main/java/org/springframework/integration/x/twitter/TwitterStreamChannelAdapter.java index 67c143778..8383944fe 100644 --- a/extensions/spring-xd-extension-twitter/src/main/java/org/springframework/integration/x/twitter/TwitterStreamChannelAdapter.java +++ b/extensions/spring-xd-extension-twitter/src/main/java/org/springframework/integration/x/twitter/TwitterStreamChannelAdapter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-twitter/src/main/java/org/springframework/integration/x/twitter/TwitterStreamOptionsMetadata.java b/extensions/spring-xd-extension-twitter/src/main/java/org/springframework/integration/x/twitter/TwitterStreamOptionsMetadata.java index 9cd64653b..53bdb5f27 100644 --- a/extensions/spring-xd-extension-twitter/src/main/java/org/springframework/integration/x/twitter/TwitterStreamOptionsMetadata.java +++ b/extensions/spring-xd-extension-twitter/src/main/java/org/springframework/integration/x/twitter/TwitterStreamOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/extensions/spring-xd-extension-twitter/src/test/java/org/springframework/integration/x/twitter/AbstractTwitterInboundChannelAdapterTests.java b/extensions/spring-xd-extension-twitter/src/test/java/org/springframework/integration/x/twitter/AbstractTwitterInboundChannelAdapterTests.java index 188eceb27..63ae44a07 100644 --- a/extensions/spring-xd-extension-twitter/src/test/java/org/springframework/integration/x/twitter/AbstractTwitterInboundChannelAdapterTests.java +++ b/extensions/spring-xd-extension-twitter/src/test/java/org/springframework/integration/x/twitter/AbstractTwitterInboundChannelAdapterTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/modules/common/shell-command-processor.xml b/modules/common/shell-command-processor.xml index e688ba2d4..af1f2a2b9 100644 --- a/modules/common/shell-command-processor.xml +++ b/modules/common/shell-command-processor.xml @@ -7,7 +7,7 @@ ~ * you may not use this file except in compliance with the License. ~ * You may obtain a copy of the License at ~ * - ~ * http://www.apache.org/licenses/LICENSE-2.0 + ~ * https://www.apache.org/licenses/LICENSE-2.0 ~ * ~ * Unless required by applicable law or agreed to in writing, software ~ * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/modules/processor/header-enricher/config/header-enricher.groovy b/modules/processor/header-enricher/config/header-enricher.groovy index 45a0a0018..c82ef7b42 100644 --- a/modules/processor/header-enricher/config/header-enricher.groovy +++ b/modules/processor/header-enricher/config/header-enricher.groovy @@ -6,7 +6,7 @@ import groovy.json.JsonSlurper * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/modules/processor/shell/config/shell.xml b/modules/processor/shell/config/shell.xml index bcfb7b3d4..09f4d7a0e 100644 --- a/modules/processor/shell/config/shell.xml +++ b/modules/processor/shell/config/shell.xml @@ -7,7 +7,7 @@ ~ * you may not use this file except in compliance with the License. ~ * You may obtain a copy of the License at ~ * - ~ * http://www.apache.org/licenses/LICENSE-2.0 + ~ * https://www.apache.org/licenses/LICENSE-2.0 ~ * ~ * Unless required by applicable law or agreed to in writing, software ~ * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/modules/sink/shell/config/shell.xml b/modules/sink/shell/config/shell.xml index 7125233df..e7f27c8cc 100644 --- a/modules/sink/shell/config/shell.xml +++ b/modules/sink/shell/config/shell.xml @@ -7,7 +7,7 @@ ~ * you may not use this file except in compliance with the License. ~ * You may obtain a copy of the License at ~ * - ~ * http://www.apache.org/licenses/LICENSE-2.0 + ~ * https://www.apache.org/licenses/LICENSE-2.0 ~ * ~ * Unless required by applicable law or agreed to in writing, software ~ * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/modules/sink/throughput-sampler/config/throughput-sampler.xml b/modules/sink/throughput-sampler/config/throughput-sampler.xml index f75806796..aa6a08eb6 100644 --- a/modules/sink/throughput-sampler/config/throughput-sampler.xml +++ b/modules/sink/throughput-sampler/config/throughput-sampler.xml @@ -6,7 +6,7 @@ ~ you may not use this file except in compliance with the License. ~ You may obtain a copy of the License at ~ - ~ http://www.apache.org/licenses/LICENSE-2.0 + ~ https://www.apache.org/licenses/LICENSE-2.0 ~ ~ Unless required by applicable law or agreed to in writing, software ~ distributed under the License is distributed on an "AS IS" BASIS, diff --git a/modules/source/reactor-ip/config/reactor-ip.xml b/modules/source/reactor-ip/config/reactor-ip.xml index 25f7ca6ac..095ea9cce 100644 --- a/modules/source/reactor-ip/config/reactor-ip.xml +++ b/modules/source/reactor-ip/config/reactor-ip.xml @@ -6,7 +6,7 @@ ~ you may not use this file except in compliance with the License. ~ You may obtain a copy of the License at ~ - ~ http://www.apache.org/licenses/LICENSE-2.0 + ~ https://www.apache.org/licenses/LICENSE-2.0 ~ ~ Unless required by applicable law or agreed to in writing, software ~ distributed under the License is distributed on an "AS IS" BASIS, diff --git a/scripts/LICENSE b/scripts/LICENSE index f02312be3..1b4abad4f 100644 --- a/scripts/LICENSE +++ b/scripts/LICENSE @@ -1,7 +1,7 @@ 2 Apache License Version 2.0, January 2004 - http://www.apache.org/licenses/ + https://www.apache.org/licenses/ TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION @@ -193,7 +193,7 @@ you may not use this file except in compliance with the License. You may obtain a copy of the License at - http://www.apache.org/licenses/LICENSE-2.0 + https://www.apache.org/licenses/LICENSE-2.0 Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics-ml/src/main/java/org/springframework/xd/analytics/ml/AbstractFieldMappingAwareDataMapper.java b/spring-xd-analytics-ml/src/main/java/org/springframework/xd/analytics/ml/AbstractFieldMappingAwareDataMapper.java index 695ab4ee2..9930b803b 100644 --- a/spring-xd-analytics-ml/src/main/java/org/springframework/xd/analytics/ml/AbstractFieldMappingAwareDataMapper.java +++ b/spring-xd-analytics-ml/src/main/java/org/springframework/xd/analytics/ml/AbstractFieldMappingAwareDataMapper.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics-ml/src/main/java/org/springframework/xd/analytics/ml/Analytic.java b/spring-xd-analytics-ml/src/main/java/org/springframework/xd/analytics/ml/Analytic.java index 84176e2e7..def1241a0 100644 --- a/spring-xd-analytics-ml/src/main/java/org/springframework/xd/analytics/ml/Analytic.java +++ b/spring-xd-analytics-ml/src/main/java/org/springframework/xd/analytics/ml/Analytic.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics-ml/src/main/java/org/springframework/xd/analytics/ml/InputMapper.java b/spring-xd-analytics-ml/src/main/java/org/springframework/xd/analytics/ml/InputMapper.java index cc291d059..c27abe323 100644 --- a/spring-xd-analytics-ml/src/main/java/org/springframework/xd/analytics/ml/InputMapper.java +++ b/spring-xd-analytics-ml/src/main/java/org/springframework/xd/analytics/ml/InputMapper.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics-ml/src/main/java/org/springframework/xd/analytics/ml/MappedAnalytic.java b/spring-xd-analytics-ml/src/main/java/org/springframework/xd/analytics/ml/MappedAnalytic.java index 2ca3feb79..698d0c33f 100644 --- a/spring-xd-analytics-ml/src/main/java/org/springframework/xd/analytics/ml/MappedAnalytic.java +++ b/spring-xd-analytics-ml/src/main/java/org/springframework/xd/analytics/ml/MappedAnalytic.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics-ml/src/main/java/org/springframework/xd/analytics/ml/Mapper.java b/spring-xd-analytics-ml/src/main/java/org/springframework/xd/analytics/ml/Mapper.java index 8f5ce2bd4..eb1dc88a2 100644 --- a/spring-xd-analytics-ml/src/main/java/org/springframework/xd/analytics/ml/Mapper.java +++ b/spring-xd-analytics-ml/src/main/java/org/springframework/xd/analytics/ml/Mapper.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics-ml/src/main/java/org/springframework/xd/analytics/ml/OutputMapper.java b/spring-xd-analytics-ml/src/main/java/org/springframework/xd/analytics/ml/OutputMapper.java index a90d6e06d..7eb3c1b2c 100644 --- a/spring-xd-analytics-ml/src/main/java/org/springframework/xd/analytics/ml/OutputMapper.java +++ b/spring-xd-analytics-ml/src/main/java/org/springframework/xd/analytics/ml/OutputMapper.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics-ml/src/test/java/org/springframework/xd/analytics/ml/AbstractFieldMappingAwareDataMapperTest.java b/spring-xd-analytics-ml/src/test/java/org/springframework/xd/analytics/ml/AbstractFieldMappingAwareDataMapperTest.java index 92abab447..3753ed8ee 100644 --- a/spring-xd-analytics-ml/src/test/java/org/springframework/xd/analytics/ml/AbstractFieldMappingAwareDataMapperTest.java +++ b/spring-xd-analytics-ml/src/test/java/org/springframework/xd/analytics/ml/AbstractFieldMappingAwareDataMapperTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics-ml/src/test/java/org/springframework/xd/analytics/ml/DummyAnalytic.java b/spring-xd-analytics-ml/src/test/java/org/springframework/xd/analytics/ml/DummyAnalytic.java index c043d089d..39fb5b6d2 100644 --- a/spring-xd-analytics-ml/src/test/java/org/springframework/xd/analytics/ml/DummyAnalytic.java +++ b/spring-xd-analytics-ml/src/test/java/org/springframework/xd/analytics/ml/DummyAnalytic.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics-ml/src/test/java/org/springframework/xd/analytics/ml/DummyInputMapper.java b/spring-xd-analytics-ml/src/test/java/org/springframework/xd/analytics/ml/DummyInputMapper.java index a7fae8932..24b5ab8b3 100644 --- a/spring-xd-analytics-ml/src/test/java/org/springframework/xd/analytics/ml/DummyInputMapper.java +++ b/spring-xd-analytics-ml/src/test/java/org/springframework/xd/analytics/ml/DummyInputMapper.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics-ml/src/test/java/org/springframework/xd/analytics/ml/DummyMappedAnalytic.java b/spring-xd-analytics-ml/src/test/java/org/springframework/xd/analytics/ml/DummyMappedAnalytic.java index a9b9fdcdd..a9836ecd0 100644 --- a/spring-xd-analytics-ml/src/test/java/org/springframework/xd/analytics/ml/DummyMappedAnalytic.java +++ b/spring-xd-analytics-ml/src/test/java/org/springframework/xd/analytics/ml/DummyMappedAnalytic.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics-ml/src/test/java/org/springframework/xd/analytics/ml/DummyOutputMapper.java b/spring-xd-analytics-ml/src/test/java/org/springframework/xd/analytics/ml/DummyOutputMapper.java index dec2cacc9..46521f72a 100644 --- a/spring-xd-analytics-ml/src/test/java/org/springframework/xd/analytics/ml/DummyOutputMapper.java +++ b/spring-xd-analytics-ml/src/test/java/org/springframework/xd/analytics/ml/DummyOutputMapper.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics-ml/src/test/java/org/springframework/xd/analytics/ml/MappedAnalyticTest.java b/spring-xd-analytics-ml/src/test/java/org/springframework/xd/analytics/ml/MappedAnalyticTest.java index 5278dbbec..ac73dddc5 100644 --- a/spring-xd-analytics-ml/src/test/java/org/springframework/xd/analytics/ml/MappedAnalyticTest.java +++ b/spring-xd-analytics-ml/src/test/java/org/springframework/xd/analytics/ml/MappedAnalyticTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/AggregateCount.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/AggregateCount.java index 1cc545fef..3ce8d151e 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/AggregateCount.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/AggregateCount.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/AggregateCountResolution.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/AggregateCountResolution.java index 8a0f324d5..7b25e3bb5 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/AggregateCountResolution.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/AggregateCountResolution.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/AggregateCounterRepository.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/AggregateCounterRepository.java index f3080a484..63973e012 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/AggregateCounterRepository.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/AggregateCounterRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/Counter.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/Counter.java index 55e073e3b..43b70b25b 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/Counter.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/Counter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/CounterRepository.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/CounterRepository.java index fd3dc279d..f276e15f5 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/CounterRepository.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/CounterRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/FieldValueCounter.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/FieldValueCounter.java index 33149b6a1..0218cf2f2 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/FieldValueCounter.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/FieldValueCounter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/FieldValueCounterRepository.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/FieldValueCounterRepository.java index 9518ae52a..09fdec25d 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/FieldValueCounterRepository.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/FieldValueCounterRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/Gauge.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/Gauge.java index 061a1ad28..581c11192 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/Gauge.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/Gauge.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/GaugeRepository.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/GaugeRepository.java index 81c10dec4..d77edddf6 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/GaugeRepository.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/GaugeRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/Metric.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/Metric.java index 18fbf0961..0f7156ec6 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/Metric.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/Metric.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/MetricRepository.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/MetricRepository.java index 9b03322b9..3dc627ede 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/MetricRepository.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/MetricRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/MetricUtils.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/MetricUtils.java index a75bdb249..0289f8b0c 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/MetricUtils.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/MetricUtils.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/RichGauge.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/RichGauge.java index 4ae617d62..6ccc72908 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/RichGauge.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/RichGauge.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/RichGaugeRepository.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/RichGaugeRepository.java index 72c90ad77..8e02c5286 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/RichGaugeRepository.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/core/RichGaugeRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/integration/AbstractMetricHandler.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/integration/AbstractMetricHandler.java index 27c219b2c..a78ec0aee 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/integration/AbstractMetricHandler.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/integration/AbstractMetricHandler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/integration/AggregateCounterHandler.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/integration/AggregateCounterHandler.java index 689237a16..681742ee2 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/integration/AggregateCounterHandler.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/integration/AggregateCounterHandler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/integration/FieldValueCounterHandler.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/integration/FieldValueCounterHandler.java index 40abc841a..a2361232b 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/integration/FieldValueCounterHandler.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/integration/FieldValueCounterHandler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/integration/GaugeHandler.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/integration/GaugeHandler.java index 9f6ddd70f..ffc807194 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/integration/GaugeHandler.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/integration/GaugeHandler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/integration/MessageCounterHandler.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/integration/MessageCounterHandler.java index e52315e5b..c9fac5f4c 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/integration/MessageCounterHandler.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/integration/MessageCounterHandler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/integration/RichGaugeHandler.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/integration/RichGaugeHandler.java index 75cfa3acc..708b6affb 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/integration/RichGaugeHandler.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/integration/RichGaugeHandler.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/memory/InMemoryAggregateCounter.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/memory/InMemoryAggregateCounter.java index ef8510ad9..ea0cd1e8b 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/memory/InMemoryAggregateCounter.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/memory/InMemoryAggregateCounter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/memory/InMemoryAggregateCounterRepository.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/memory/InMemoryAggregateCounterRepository.java index 061007e5d..1c07ff6e1 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/memory/InMemoryAggregateCounterRepository.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/memory/InMemoryAggregateCounterRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/memory/InMemoryCounterRepository.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/memory/InMemoryCounterRepository.java index f78f39cef..a98963757 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/memory/InMemoryCounterRepository.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/memory/InMemoryCounterRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/memory/InMemoryFieldValueCounterRepository.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/memory/InMemoryFieldValueCounterRepository.java index 7f1fa3acb..c84302213 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/memory/InMemoryFieldValueCounterRepository.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/memory/InMemoryFieldValueCounterRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/memory/InMemoryGaugeRepository.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/memory/InMemoryGaugeRepository.java index f6ab10d85..d43dedd86 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/memory/InMemoryGaugeRepository.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/memory/InMemoryGaugeRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/memory/InMemoryMetricRepository.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/memory/InMemoryMetricRepository.java index 6f2c3107c..bcad5ad75 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/memory/InMemoryMetricRepository.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/memory/InMemoryMetricRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/memory/InMemoryRichGaugeRepository.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/memory/InMemoryRichGaugeRepository.java index b3060b61f..adbe721fa 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/memory/InMemoryRichGaugeRepository.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/memory/InMemoryRichGaugeRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/metadata/AggregateCounterSinkOptionsMetadata.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/metadata/AggregateCounterSinkOptionsMetadata.java index dc95baa49..bc729a6c4 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/metadata/AggregateCounterSinkOptionsMetadata.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/metadata/AggregateCounterSinkOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/metadata/FieldValueCounterSinkOptionsMetadata.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/metadata/FieldValueCounterSinkOptionsMetadata.java index 1c09da1b4..1697d6dd9 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/metadata/FieldValueCounterSinkOptionsMetadata.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/metadata/FieldValueCounterSinkOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/metadata/MetricNameMixin.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/metadata/MetricNameMixin.java index 22e54e6e0..af0a63ded 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/metadata/MetricNameMixin.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/metadata/MetricNameMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/metadata/RichGaugeSinkOptionsMetadata.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/metadata/RichGaugeSinkOptionsMetadata.java index d54a2e890..164fc3138 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/metadata/RichGaugeSinkOptionsMetadata.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/metadata/RichGaugeSinkOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/AbstractRedisMetricRepository.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/AbstractRedisMetricRepository.java index aa5163fe9..2beb9ba5b 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/AbstractRedisMetricRepository.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/AbstractRedisMetricRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/AggregateKeyGenerator.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/AggregateKeyGenerator.java index cc96a1088..782adaa23 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/AggregateKeyGenerator.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/AggregateKeyGenerator.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/LoggingRecoveryCallback.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/LoggingRecoveryCallback.java index 111b75d85..3f174a572 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/LoggingRecoveryCallback.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/LoggingRecoveryCallback.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/RedisAggregateCounterRepository.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/RedisAggregateCounterRepository.java index 7e274cace..1944c8556 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/RedisAggregateCounterRepository.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/RedisAggregateCounterRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/RedisCounterRepository.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/RedisCounterRepository.java index 56f6b05a6..2f36d82d9 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/RedisCounterRepository.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/RedisCounterRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/RedisFieldValueCounterRepository.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/RedisFieldValueCounterRepository.java index 47d457231..11fb23f82 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/RedisFieldValueCounterRepository.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/RedisFieldValueCounterRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/RedisGaugeRepository.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/RedisGaugeRepository.java index f7e74c87d..08b377238 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/RedisGaugeRepository.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/RedisGaugeRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/RedisRetryTemplate.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/RedisRetryTemplate.java index 10f3c3060..ff33b3827 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/RedisRetryTemplate.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/RedisRetryTemplate.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/RedisRichGaugeRepository.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/RedisRichGaugeRepository.java index 8ee5544d2..ec2aa25c4 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/RedisRichGaugeRepository.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/RedisRichGaugeRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/RedisUtils.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/RedisUtils.java index e2fa0f633..2c8ba54a7 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/RedisUtils.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/RedisUtils.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/StringRedisRetryTemplate.java b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/StringRedisRetryTemplate.java index 322b751ff..a7f10be0f 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/StringRedisRetryTemplate.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/analytics/metrics/redis/StringRedisRetryTemplate.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/store/AbstractInMemoryRepository.java b/spring-xd-analytics/src/main/java/org/springframework/xd/store/AbstractInMemoryRepository.java index afd8bb6c5..9fdb2ed7c 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/store/AbstractInMemoryRepository.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/store/AbstractInMemoryRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/store/AbstractRedisRepository.java b/spring-xd-analytics/src/main/java/org/springframework/xd/store/AbstractRedisRepository.java index f79302518..ba2dbe990 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/store/AbstractRedisRepository.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/store/AbstractRedisRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/store/AbstractRepository.java b/spring-xd-analytics/src/main/java/org/springframework/xd/store/AbstractRepository.java index 7faf9d4df..cee018112 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/store/AbstractRepository.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/store/AbstractRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/store/DomainRepository.java b/spring-xd-analytics/src/main/java/org/springframework/xd/store/DomainRepository.java index 061e246f0..b1b810336 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/store/DomainRepository.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/store/DomainRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/main/java/org/springframework/xd/store/RangeCapableRepository.java b/spring-xd-analytics/src/main/java/org/springframework/xd/store/RangeCapableRepository.java index 39fb25745..03600edff 100644 --- a/spring-xd-analytics/src/main/java/org/springframework/xd/store/RangeCapableRepository.java +++ b/spring-xd-analytics/src/main/java/org/springframework/xd/store/RangeCapableRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/AbstractAggregateCounterTests.java b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/AbstractAggregateCounterTests.java index 9e522155d..f29e1ca9f 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/AbstractAggregateCounterTests.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/AbstractAggregateCounterTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/AbstractCounterRepositoryTests.java b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/AbstractCounterRepositoryTests.java index ad70c50fb..f87ccfd2e 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/AbstractCounterRepositoryTests.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/AbstractCounterRepositoryTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/AbstractFieldValueCounterRepositoryTests.java b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/AbstractFieldValueCounterRepositoryTests.java index 1a3d070f4..9bd813a42 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/AbstractFieldValueCounterRepositoryTests.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/AbstractFieldValueCounterRepositoryTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/AbstractRichGaugeRepositoryTests.java b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/AbstractRichGaugeRepositoryTests.java index 0f6ec2df6..4f3f14214 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/AbstractRichGaugeRepositoryTests.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/AbstractRichGaugeRepositoryTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/SharedGaugeRepositoryTests.java b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/SharedGaugeRepositoryTests.java index 1f9054bbf..25f608483 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/SharedGaugeRepositoryTests.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/SharedGaugeRepositoryTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/common/RedisRepositoriesConfig.java b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/common/RedisRepositoriesConfig.java index fd70854bf..466e456b6 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/common/RedisRepositoriesConfig.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/common/RedisRepositoriesConfig.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/core/CounterTests.java b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/core/CounterTests.java index 482351567..b403ad37b 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/core/CounterTests.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/core/CounterTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/core/FieldValueCounterTests.java b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/core/FieldValueCounterTests.java index 915a55f66..66efd6154 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/core/FieldValueCounterTests.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/core/FieldValueCounterTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/core/GaugeTests.java b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/core/GaugeTests.java index 43647d648..7a849659d 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/core/GaugeTests.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/core/GaugeTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/core/MetricUtilsTests.java b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/core/MetricUtilsTests.java index edeaa2327..909a01bc8 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/core/MetricUtilsTests.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/core/MetricUtilsTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/core/RichGaugeTests.java b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/core/RichGaugeTests.java index 5a61fb7d5..51506a6f6 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/core/RichGaugeTests.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/core/RichGaugeTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/integration/AggregateCounterTests.java b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/integration/AggregateCounterTests.java index 96df355b7..6944cdb4a 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/integration/AggregateCounterTests.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/integration/AggregateCounterTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/integration/FieldValueCounterHandlerTests.java b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/integration/FieldValueCounterHandlerTests.java index bf4ca82de..2770105a3 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/integration/FieldValueCounterHandlerTests.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/integration/FieldValueCounterHandlerTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/integration/GaugeHandlerTests.java b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/integration/GaugeHandlerTests.java index e6a4c8cb9..1356aca8f 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/integration/GaugeHandlerTests.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/integration/GaugeHandlerTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/integration/MessageCounterHandlerTests.java b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/integration/MessageCounterHandlerTests.java index e7af48188..c58b7283c 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/integration/MessageCounterHandlerTests.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/integration/MessageCounterHandlerTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/integration/RichGaugeHandlerTests.java b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/integration/RichGaugeHandlerTests.java index e9855b430..f60d49a15 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/integration/RichGaugeHandlerTests.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/integration/RichGaugeHandlerTests.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/integration/SimpleTweet.java b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/integration/SimpleTweet.java index 3bb757d4d..7e97c828f 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/integration/SimpleTweet.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/integration/SimpleTweet.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/memory/InMemoryAggregateCounterTests.java b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/memory/InMemoryAggregateCounterTests.java index 19948bf6a..98600cfde 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/memory/InMemoryAggregateCounterTests.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/memory/InMemoryAggregateCounterTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/memory/InMemoryCounterRepositoryTests.java b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/memory/InMemoryCounterRepositoryTests.java index 271876552..8512428b2 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/memory/InMemoryCounterRepositoryTests.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/memory/InMemoryCounterRepositoryTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/memory/InMemoryFieldValueCounterRepositoryTests.java b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/memory/InMemoryFieldValueCounterRepositoryTests.java index fee78ba14..96dd31e71 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/memory/InMemoryFieldValueCounterRepositoryTests.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/memory/InMemoryFieldValueCounterRepositoryTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/memory/InMemoryGaugeRepositoryTests.java b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/memory/InMemoryGaugeRepositoryTests.java index 457b6127a..6dce7363f 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/memory/InMemoryGaugeRepositoryTests.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/memory/InMemoryGaugeRepositoryTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/memory/InMemoryRichGaugeRepositoryTests.java b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/memory/InMemoryRichGaugeRepositoryTests.java index 7fbd9e4ca..302d051f4 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/memory/InMemoryRichGaugeRepositoryTests.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/memory/InMemoryRichGaugeRepositoryTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/redis/RedisAggregateCounterTests.java b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/redis/RedisAggregateCounterTests.java index 43e3cd3d8..a6f118ea8 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/redis/RedisAggregateCounterTests.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/redis/RedisAggregateCounterTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/redis/RedisCounterRepositoryTests.java b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/redis/RedisCounterRepositoryTests.java index 661c89000..3ea8ed545 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/redis/RedisCounterRepositoryTests.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/redis/RedisCounterRepositoryTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/redis/RedisFieldValueCounterRepositoryTests.java b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/redis/RedisFieldValueCounterRepositoryTests.java index 5ac60139b..1c78d724b 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/redis/RedisFieldValueCounterRepositoryTests.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/redis/RedisFieldValueCounterRepositoryTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/redis/RedisGaugeRepositoryTests.java b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/redis/RedisGaugeRepositoryTests.java index c4e92e9c0..82e651cac 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/redis/RedisGaugeRepositoryTests.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/redis/RedisGaugeRepositoryTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/redis/RedisRetryTemplateTests.java b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/redis/RedisRetryTemplateTests.java index 72fbcdd3e..66dc41a02 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/redis/RedisRetryTemplateTests.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/redis/RedisRetryTemplateTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/redis/RedisRichGaugeRepositoryTests.java b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/redis/RedisRichGaugeRepositoryTests.java index 13836d6f5..1c8fd3d2e 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/redis/RedisRichGaugeRepositoryTests.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/analytics/metrics/redis/RedisRichGaugeRepositoryTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/store/AbstractInMemoryRepositoryTests.java b/spring-xd-analytics/src/test/java/org/springframework/xd/store/AbstractInMemoryRepositoryTests.java index 447ce01fc..d390b02e8 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/store/AbstractInMemoryRepositoryTests.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/store/AbstractInMemoryRepositoryTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/store/AbstractRedisRepositoryTests.java b/spring-xd-analytics/src/test/java/org/springframework/xd/store/AbstractRedisRepositoryTests.java index 248ff8cfd..35103e383 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/store/AbstractRedisRepositoryTests.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/store/AbstractRedisRepositoryTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-analytics/src/test/java/org/springframework/xd/store/BaseRepositoryTests.java b/spring-xd-analytics/src/test/java/org/springframework/xd/store/BaseRepositoryTests.java index ab34bc27e..1e66d62ed 100644 --- a/spring-xd-analytics/src/test/java/org/springframework/xd/store/BaseRepositoryTests.java +++ b/spring-xd-analytics/src/test/java/org/springframework/xd/store/BaseRepositoryTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-batch/src/main/java/org/springframework/xd/batch/XdBatchDatabaseInitializer.java b/spring-xd-batch/src/main/java/org/springframework/xd/batch/XdBatchDatabaseInitializer.java index 4f3bfbe5b..d95f75c50 100644 --- a/spring-xd-batch/src/main/java/org/springframework/xd/batch/XdBatchDatabaseInitializer.java +++ b/spring-xd-batch/src/main/java/org/springframework/xd/batch/XdBatchDatabaseInitializer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-batch/src/main/java/org/springframework/xd/batch/hsqldb/server/HSQLServerBean.java b/spring-xd-batch/src/main/java/org/springframework/xd/batch/hsqldb/server/HSQLServerBean.java index 33834dede..725de1195 100644 --- a/spring-xd-batch/src/main/java/org/springframework/xd/batch/hsqldb/server/HSQLServerBean.java +++ b/spring-xd-batch/src/main/java/org/springframework/xd/batch/hsqldb/server/HSQLServerBean.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-batch/src/main/java/org/springframework/xd/batch/hsqldb/server/HsqlDatasourceConfiguration.java b/spring-xd-batch/src/main/java/org/springframework/xd/batch/hsqldb/server/HsqlDatasourceConfiguration.java index 07cf11bb2..692218f39 100644 --- a/spring-xd-batch/src/main/java/org/springframework/xd/batch/hsqldb/server/HsqlDatasourceConfiguration.java +++ b/spring-xd-batch/src/main/java/org/springframework/xd/batch/hsqldb/server/HsqlDatasourceConfiguration.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-batch/src/main/java/org/springframework/xd/batch/hsqldb/server/HsqlServerApplication.java b/spring-xd-batch/src/main/java/org/springframework/xd/batch/hsqldb/server/HsqlServerApplication.java index 641a1dff7..a1eb752f2 100644 --- a/spring-xd-batch/src/main/java/org/springframework/xd/batch/hsqldb/server/HsqlServerApplication.java +++ b/spring-xd-batch/src/main/java/org/springframework/xd/batch/hsqldb/server/HsqlServerApplication.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-batch/src/main/java/org/springframework/xd/batch/item/jdbc/FieldSetSqlParameterSourceProvider.java b/spring-xd-batch/src/main/java/org/springframework/xd/batch/item/jdbc/FieldSetSqlParameterSourceProvider.java index 2882cce89..d9cb33f19 100644 --- a/spring-xd-batch/src/main/java/org/springframework/xd/batch/item/jdbc/FieldSetSqlParameterSourceProvider.java +++ b/spring-xd-batch/src/main/java/org/springframework/xd/batch/item/jdbc/FieldSetSqlParameterSourceProvider.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-benchmark/src/test/java/org/springframework/xd/dirt/integration/bus/MessageBusSupportBenchmarkTests.java b/spring-xd-benchmark/src/test/java/org/springframework/xd/dirt/integration/bus/MessageBusSupportBenchmarkTests.java index 3b86825c4..32c348fcf 100644 --- a/spring-xd-benchmark/src/test/java/org/springframework/xd/dirt/integration/bus/MessageBusSupportBenchmarkTests.java +++ b/spring-xd-benchmark/src/test/java/org/springframework/xd/dirt/integration/bus/MessageBusSupportBenchmarkTests.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-benchmark/src/test/java/org/springframework/xd/tuple/TupleCreationPerformanceTests.java b/spring-xd-benchmark/src/test/java/org/springframework/xd/tuple/TupleCreationPerformanceTests.java index 088734b85..a62fae615 100644 --- a/spring-xd-benchmark/src/test/java/org/springframework/xd/tuple/TupleCreationPerformanceTests.java +++ b/spring-xd-benchmark/src/test/java/org/springframework/xd/tuple/TupleCreationPerformanceTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-benchmark/src/test/java/org/springframework/xd/tuple/serializer/kryo/TupleCodecBenchmarkTests.java b/spring-xd-benchmark/src/test/java/org/springframework/xd/tuple/serializer/kryo/TupleCodecBenchmarkTests.java index 5665261ae..38c786a19 100644 --- a/spring-xd-benchmark/src/test/java/org/springframework/xd/tuple/serializer/kryo/TupleCodecBenchmarkTests.java +++ b/spring-xd-benchmark/src/test/java/org/springframework/xd/tuple/serializer/kryo/TupleCodecBenchmarkTests.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/DirtException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/DirtException.java index cfd8cc813..93b3635b5 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/DirtException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/DirtException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/analytics/NoSuchMetricException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/analytics/NoSuchMetricException.java index ca51913db..e8d48c297 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/analytics/NoSuchMetricException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/analytics/NoSuchMetricException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/batch/RuntimeBatchConfigurer.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/batch/RuntimeBatchConfigurer.java index 65a851d6e..cd0fbe858 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/batch/RuntimeBatchConfigurer.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/batch/RuntimeBatchConfigurer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/batch/tasklet/JobLaunchingTasklet.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/batch/tasklet/JobLaunchingTasklet.java index 6dea23a2a..898931413 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/batch/tasklet/JobLaunchingTasklet.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/batch/tasklet/JobLaunchingTasklet.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/Admin.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/Admin.java index 292f2aeab..d3fea4ee8 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/Admin.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/Admin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/AdminAttributes.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/AdminAttributes.java index 3e973fbc8..ce74403a7 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/AdminAttributes.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/AdminAttributes.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/Container.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/Container.java index ceee147e1..3d2065646 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/Container.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/Container.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/ContainerAttributes.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/ContainerAttributes.java index c96b0961e..dfeb5eb5b 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/ContainerAttributes.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/ContainerAttributes.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/ContainerFilter.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/ContainerFilter.java index d2efd259a..512a35fb0 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/ContainerFilter.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/ContainerFilter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/ContainerShutdownException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/ContainerShutdownException.java index acb8ec5d3..0bbdb6632 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/ContainerShutdownException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/ContainerShutdownException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/ModuleMessageRateNotFoundException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/ModuleMessageRateNotFoundException.java index 2ee76fdc0..1d6fcc0d0 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/ModuleMessageRateNotFoundException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/ModuleMessageRateNotFoundException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/NoContainerException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/NoContainerException.java index faf541674..8bf53e0e3 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/NoContainerException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/NoContainerException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/NoSuchContainerException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/NoSuchContainerException.java index 201fc5648..83bca1a82 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/NoSuchContainerException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/cluster/NoSuchContainerException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/decryptor/DecryptorContext.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/decryptor/DecryptorContext.java index 27ca22e73..af66a7fbd 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/decryptor/DecryptorContext.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/decryptor/DecryptorContext.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/decryptor/PropertiesDecryptor.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/decryptor/PropertiesDecryptor.java index b03db0169..5d6858a1d 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/decryptor/PropertiesDecryptor.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/decryptor/PropertiesDecryptor.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/initializer/AbstractComponentScanningBeanDefinitionProvider.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/initializer/AbstractComponentScanningBeanDefinitionProvider.java index 2e7ac9547..baaeab3ad 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/initializer/AbstractComponentScanningBeanDefinitionProvider.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/initializer/AbstractComponentScanningBeanDefinitionProvider.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/initializer/AbstractResourceBeanDefinitionProvider.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/initializer/AbstractResourceBeanDefinitionProvider.java index ca9a1a1b4..bc2b1ee9f 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/initializer/AbstractResourceBeanDefinitionProvider.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/initializer/AbstractResourceBeanDefinitionProvider.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/initializer/OrderedContextInitializer.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/initializer/OrderedContextInitializer.java index 2fa49cb68..cf6a7dca1 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/initializer/OrderedContextInitializer.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/initializer/OrderedContextInitializer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/initializer/PluginContextComponentScanningExtensionsInitializer.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/initializer/PluginContextComponentScanningExtensionsInitializer.java index 0b15854bd..e388c4d3d 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/initializer/PluginContextComponentScanningExtensionsInitializer.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/initializer/PluginContextComponentScanningExtensionsInitializer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/initializer/PluginContextResourceExtensionsInitializer.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/initializer/PluginContextResourceExtensionsInitializer.java index 8215174d3..4e1b1e583 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/initializer/PluginContextResourceExtensionsInitializer.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/initializer/PluginContextResourceExtensionsInitializer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/initializer/PluginsInitializer.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/initializer/PluginsInitializer.java index 7f8e746fe..747704412 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/initializer/PluginsInitializer.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/initializer/PluginsInitializer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/store/AdminRepository.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/store/AdminRepository.java index 7d9bfc1ab..775015a1b 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/store/AdminRepository.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/store/AdminRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/store/ContainerRepository.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/store/ContainerRepository.java index d5319a340..506afe143 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/store/ContainerRepository.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/store/ContainerRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/store/DetailedContainer.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/store/DetailedContainer.java index e2d810bbb..30ca01be5 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/store/DetailedContainer.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/store/DetailedContainer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/store/ZooKeeperAdminRepository.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/store/ZooKeeperAdminRepository.java index 1114b1bc5..2ae64463c 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/store/ZooKeeperAdminRepository.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/store/ZooKeeperAdminRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/store/ZooKeeperContainerRepository.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/store/ZooKeeperContainerRepository.java index 9f94b2fa1..f764ace4c 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/store/ZooKeeperContainerRepository.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/container/store/ZooKeeperContainerRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/BaseDefinition.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/BaseDefinition.java index 0ee940aab..52708eb3b 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/BaseDefinition.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/BaseDefinition.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/DeploymentStatusRepository.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/DeploymentStatusRepository.java index 0d6b07d42..a14e3f6d5 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/DeploymentStatusRepository.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/DeploymentStatusRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/DeploymentUnit.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/DeploymentUnit.java index 3d6fbceb7..ee0bd6d6d 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/DeploymentUnit.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/DeploymentUnit.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/DeploymentUnitStatus.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/DeploymentUnitStatus.java index 8bc4d9edf..113141939 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/DeploymentUnitStatus.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/DeploymentUnitStatus.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/Job.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/Job.java index 7f61cbbb5..28ec364a0 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/Job.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/Job.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/JobDeploymentsPath.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/JobDeploymentsPath.java index 9cdd04fa2..24d57123d 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/JobDeploymentsPath.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/JobDeploymentsPath.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/ModuleDeploymentRequestsPath.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/ModuleDeploymentRequestsPath.java index df5284126..d8054619c 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/ModuleDeploymentRequestsPath.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/ModuleDeploymentRequestsPath.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/ModuleDeploymentsPath.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/ModuleDeploymentsPath.java index d083c9379..d7e078214 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/ModuleDeploymentsPath.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/ModuleDeploymentsPath.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/ResourceDeployer.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/ResourceDeployer.java index a02f41402..3df00b460 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/ResourceDeployer.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/ResourceDeployer.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/RuntimeIOException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/RuntimeIOException.java index 685d4d695..1ce727f5e 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/RuntimeIOException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/RuntimeIOException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/RuntimeTimeoutException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/RuntimeTimeoutException.java index 2b2a22f62..3695f5dd5 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/RuntimeTimeoutException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/RuntimeTimeoutException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/Stream.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/Stream.java index bc77abe3e..8250ffced 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/Stream.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/Stream.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/StreamDeploymentsPath.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/StreamDeploymentsPath.java index 426076619..26567e20e 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/StreamDeploymentsPath.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/core/StreamDeploymentsPath.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/event/AbstractEvent.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/event/AbstractEvent.java index 21fbfc1dc..974e6e5ca 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/event/AbstractEvent.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/event/AbstractEvent.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/event/AbstractModuleEvent.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/event/AbstractModuleEvent.java index eaa93758f..fb2031b63 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/event/AbstractModuleEvent.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/event/AbstractModuleEvent.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/event/ModuleDeployedEvent.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/event/ModuleDeployedEvent.java index bdc604933..56d8040f1 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/event/ModuleDeployedEvent.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/event/ModuleDeployedEvent.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/event/ModuleUndeployedEvent.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/event/ModuleUndeployedEvent.java index 6796b5cfb..3e147834d 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/event/ModuleUndeployedEvent.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/event/ModuleUndeployedEvent.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/BusCleaner.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/BusCleaner.java index ad43c0de5..4bfa7108f 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/BusCleaner.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/BusCleaner.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/MessageBusAwareChannelResolver.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/MessageBusAwareChannelResolver.java index 6a5f72551..676171450 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/MessageBusAwareChannelResolver.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/MessageBusAwareChannelResolver.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/MessageBusAwareRouterBeanPostProcessor.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/MessageBusAwareRouterBeanPostProcessor.java index 535e745b9..61e68a589 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/MessageBusAwareRouterBeanPostProcessor.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/MessageBusAwareRouterBeanPostProcessor.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/StrictContentTypeResolver.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/StrictContentTypeResolver.java index f7d9f51d7..5b775092c 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/StrictContentTypeResolver.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/StrictContentTypeResolver.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/AbstractFromMessageConverter.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/AbstractFromMessageConverter.java index 89820ae9a..ce08f691b 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/AbstractFromMessageConverter.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/AbstractFromMessageConverter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/ByteArrayToStringMessageConverter.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/ByteArrayToStringMessageConverter.java index e13b852fe..fd362157b 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/ByteArrayToStringMessageConverter.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/ByteArrayToStringMessageConverter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/CompositeMessageConverterFactory.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/CompositeMessageConverterFactory.java index f778cf079..27c38cd81 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/CompositeMessageConverterFactory.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/CompositeMessageConverterFactory.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/ConversionException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/ConversionException.java index d63907d9f..cf7ff75f6 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/ConversionException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/ConversionException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/JavaToSerializedMessageConverter.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/JavaToSerializedMessageConverter.java index 210305895..01794477e 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/JavaToSerializedMessageConverter.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/JavaToSerializedMessageConverter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/JsonToPojoMessageConverter.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/JsonToPojoMessageConverter.java index ff3fa351c..062e0a19c 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/JsonToPojoMessageConverter.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/JsonToPojoMessageConverter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/JsonToTupleMessageConverter.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/JsonToTupleMessageConverter.java index decf121e6..444701e67 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/JsonToTupleMessageConverter.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/JsonToTupleMessageConverter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/MessageConverterUtils.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/MessageConverterUtils.java index e61b76ae0..0af070395 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/MessageConverterUtils.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/MessageConverterUtils.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/PojoToJsonMessageConverter.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/PojoToJsonMessageConverter.java index f87f840e1..7db4ff862 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/PojoToJsonMessageConverter.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/PojoToJsonMessageConverter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/PojoToStringMessageConverter.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/PojoToStringMessageConverter.java index a84d6ab96..e83e6b3b2 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/PojoToStringMessageConverter.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/PojoToStringMessageConverter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/SerializedToJavaMessageConverter.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/SerializedToJavaMessageConverter.java index 34d10aee4..077d168a9 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/SerializedToJavaMessageConverter.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/SerializedToJavaMessageConverter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/StringToByteArrayMessageConverter.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/StringToByteArrayMessageConverter.java index c6b7066bd..01de1aaa3 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/StringToByteArrayMessageConverter.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/StringToByteArrayMessageConverter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/TupleToJsonMessageConverter.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/TupleToJsonMessageConverter.java index ae052bc65..81fbcbe43 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/TupleToJsonMessageConverter.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/converter/TupleToJsonMessageConverter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/rabbit/NothingToDeleteException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/rabbit/NothingToDeleteException.java index 04b17bd43..0e53fa5ca 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/rabbit/NothingToDeleteException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/rabbit/NothingToDeleteException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/rabbit/RabbitBusCleaner.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/rabbit/RabbitBusCleaner.java index 5fe9f9e4c..0179b60b5 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/rabbit/RabbitBusCleaner.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/bus/rabbit/RabbitBusCleaner.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/json/NewJsonPathUtils.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/json/NewJsonPathUtils.java index ae20b1f55..1c4e24dfe 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/json/NewJsonPathUtils.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/integration/json/NewJsonPathUtils.java @@ -6,7 +6,7 @@ * * you may not use this file except in compliance with the License. * * You may obtain a copy of the License at * * - * * http://www.apache.org/licenses/LICENSE-2.0 + * * https://www.apache.org/licenses/LICENSE-2.0 * * * * Unless required by applicable law or agreed to in writing, software * * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/jdbc/util/DatabaseVendorFriendlyNameFactoryBean.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/jdbc/util/DatabaseVendorFriendlyNameFactoryBean.java index f62846067..1503bafd3 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/jdbc/util/DatabaseVendorFriendlyNameFactoryBean.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/jdbc/util/DatabaseVendorFriendlyNameFactoryBean.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/BatchJobAlreadyExistsException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/BatchJobAlreadyExistsException.java index 91a4289b0..599f69315 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/BatchJobAlreadyExistsException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/BatchJobAlreadyExistsException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/DetailedJobInfo.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/DetailedJobInfo.java index 89762eff5..5ef61f42f 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/DetailedJobInfo.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/DetailedJobInfo.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobException.java index 8919efeef..922d72cf1 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobExecutionAlreadyRunningException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobExecutionAlreadyRunningException.java index 5cefb247d..3b483f73e 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobExecutionAlreadyRunningException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobExecutionAlreadyRunningException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobExecutionInfo.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobExecutionInfo.java index 9bb00f43c..dd2bdf1d7 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobExecutionInfo.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobExecutionInfo.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobExecutionNotRunningException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobExecutionNotRunningException.java index 9bb1d098f..67e235210 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobExecutionNotRunningException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobExecutionNotRunningException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobFactory.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobFactory.java index 89338dfe3..3c668a469 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobFactory.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobFactory.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobInfo.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobInfo.java index 9d45a7b9b..dc421f079 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobInfo.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobInfo.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobInstanceAlreadyCompleteException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobInstanceAlreadyCompleteException.java index b13585b64..fade40171 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobInstanceAlreadyCompleteException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobInstanceAlreadyCompleteException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobInstanceInfo.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobInstanceInfo.java index d9b3264cc..607b37fcc 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobInstanceInfo.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobInstanceInfo.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobParametersInvalidException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobParametersInvalidException.java index 5389acf5f..0be6fd741 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobParametersInvalidException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobParametersInvalidException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobRestartException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobRestartException.java index 998eb71cd..663f6c127 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobRestartException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/JobRestartException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/NoSuchBatchJobException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/NoSuchBatchJobException.java index 3317930b6..3a86677be 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/NoSuchBatchJobException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/NoSuchBatchJobException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/NoSuchBatchJobInstanceException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/NoSuchBatchJobInstanceException.java index 61fea8fe4..71a8f870e 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/NoSuchBatchJobInstanceException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/NoSuchBatchJobInstanceException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/NoSuchJobExecutionException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/NoSuchJobExecutionException.java index a9bd71179..855d50722 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/NoSuchJobExecutionException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/NoSuchJobExecutionException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/NoSuchStepExecutionException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/NoSuchStepExecutionException.java index a56430e54..36a0f9361 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/NoSuchStepExecutionException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/NoSuchStepExecutionException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/StepExecutionInfo.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/StepExecutionInfo.java index 2cac8262f..d7de60dd5 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/StepExecutionInfo.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/StepExecutionInfo.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/StepExecutionProgressInfo.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/StepExecutionProgressInfo.java index 44c0305e9..2e38183c0 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/StepExecutionProgressInfo.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/StepExecutionProgressInfo.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/StepType.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/StepType.java index 569e7c7d0..331fd4a75 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/StepType.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/StepType.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/TaskletType.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/TaskletType.java index 05f0c02a7..77b7aabc4 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/TaskletType.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/TaskletType.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dao/XdJdbcSearchableJobExecutionDao.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dao/XdJdbcSearchableJobExecutionDao.java index 125de1b3d..517bf5034 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dao/XdJdbcSearchableJobExecutionDao.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dao/XdJdbcSearchableJobExecutionDao.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/ArgumentNode.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/ArgumentNode.java index b3c881e17..520779cde 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/ArgumentNode.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/ArgumentNode.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/AstNode.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/AstNode.java index 885a494e1..4eeaaa2d2 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/AstNode.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/AstNode.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/CheckpointedJobDefinitionException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/CheckpointedJobDefinitionException.java index 060f9c828..98d21ea5f 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/CheckpointedJobDefinitionException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/CheckpointedJobDefinitionException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/ComposedJobUtil.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/ComposedJobUtil.java index 2a9f41156..5d599491a 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/ComposedJobUtil.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/ComposedJobUtil.java @@ -6,7 +6,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Flow.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Flow.java index 7e773554f..e0eacb894 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Flow.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Flow.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Graph.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Graph.java index d8a679d8d..1e96913ca 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Graph.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Graph.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobDSLMessage.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobDSLMessage.java index 84e10baa5..4a54e20ad 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobDSLMessage.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobDSLMessage.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobDefinition.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobDefinition.java index 7f2ae2127..dd82b6343 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobDefinition.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobDefinition.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobDescriptor.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobDescriptor.java index 825a53e9c..85698e1a7 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobDescriptor.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobDescriptor.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobNode.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobNode.java index f082326d6..6e6597063 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobNode.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobNode.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobParser.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobParser.java index 2e6322d66..86dbc2b57 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobParser.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobParser.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobReference.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobReference.java index a134e81b8..d77360215 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobReference.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobReference.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobSeries.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobSeries.java index 6004534a9..678d737da 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobSeries.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobSeries.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobSpecification.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobSpecification.java index 4ca6fa5e0..db56dd624 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobSpecification.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobSpecification.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobSpecificationException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobSpecificationException.java index c536b60d1..2b2c5503f 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobSpecificationException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobSpecificationException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobSpecificationVisitor.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobSpecificationVisitor.java index fcc1a7864..afcce46b8 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobSpecificationVisitor.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/JobSpecificationVisitor.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Link.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Link.java index 07c2d41b4..bfbb232ae 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Link.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Link.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Node.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Node.java index 7141211b1..101c1a7ed 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Node.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Node.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Split.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Split.java index e6a93f72f..4d83041dd 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Split.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Split.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Token.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Token.java index d60163c44..c28431c31 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Token.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Token.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/TokenKind.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/TokenKind.java index d5b194aa3..b29dc46a6 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/TokenKind.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/TokenKind.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Tokenizer.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Tokenizer.java index 7660dfc0a..cf50db9c5 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Tokenizer.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Tokenizer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Tokens.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Tokens.java index fd85fbc68..5a47f44bc 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Tokens.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Tokens.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Transition.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Transition.java index 3db05cc44..a45946f44 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Transition.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/job/dsl/Transition.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/CustomModuleRegistryFactoryBean.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/CustomModuleRegistryFactoryBean.java index 19bc027ba..6d803b09d 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/CustomModuleRegistryFactoryBean.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/CustomModuleRegistryFactoryBean.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/DelegatingModuleRegistry.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/DelegatingModuleRegistry.java index 9e8981a01..80d8a95dc 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/DelegatingModuleRegistry.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/DelegatingModuleRegistry.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/DependencyException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/DependencyException.java index 861a64d50..84fd02eac 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/DependencyException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/DependencyException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ExtendedResource.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ExtendedResource.java index 677403859..a74180f94 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ExtendedResource.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ExtendedResource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/MD5StalenessCheck.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/MD5StalenessCheck.java index 0013d5458..aacccac21 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/MD5StalenessCheck.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/MD5StalenessCheck.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ModuleAlreadyExistsException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ModuleAlreadyExistsException.java index 53f5b2e54..1c686fe2f 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ModuleAlreadyExistsException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ModuleAlreadyExistsException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ModuleDependencyRepository.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ModuleDependencyRepository.java index e02353989..9934bf959 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ModuleDependencyRepository.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ModuleDependencyRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ModuleDeployer.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ModuleDeployer.java index 3e0dcd98e..18d0ec943 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ModuleDeployer.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ModuleDeployer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ModuleException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ModuleException.java index bafcc6bae..24831f111 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ModuleException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ModuleException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ModuleNotDeployedException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ModuleNotDeployedException.java index ee3342582..c4fc2c7ad 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ModuleNotDeployedException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ModuleNotDeployedException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ModuleRegistry.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ModuleRegistry.java index 145b2ea1e..410a3102e 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ModuleRegistry.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ModuleRegistry.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/NoSuchModuleException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/NoSuchModuleException.java index bef14000d..35704d699 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/NoSuchModuleException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/NoSuchModuleException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ResourceDefinitionException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ResourceDefinitionException.java index 8aa9ed86f..61af47f25 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ResourceDefinitionException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ResourceDefinitionException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ResourceModuleRegistry.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ResourceModuleRegistry.java index 891ff4ad4..2dde500ae 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ResourceModuleRegistry.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/ResourceModuleRegistry.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/StalenessCheck.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/StalenessCheck.java index bc47f475f..929cf8c0a 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/StalenessCheck.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/StalenessCheck.java @@ -6,7 +6,7 @@ * * you may not use this file except in compliance with the License. * * You may obtain a copy of the License at * * - * * http://www.apache.org/licenses/LICENSE-2.0 + * * https://www.apache.org/licenses/LICENSE-2.0 * * * * Unless required by applicable law or agreed to in writing, software * * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/SynchronizingModuleRegistry.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/SynchronizingModuleRegistry.java index 140b124a8..e3036d156 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/SynchronizingModuleRegistry.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/SynchronizingModuleRegistry.java @@ -6,7 +6,7 @@ * * you may not use this file except in compliance with the License. * * You may obtain a copy of the License at * * - * * http://www.apache.org/licenses/LICENSE-2.0 + * * https://www.apache.org/licenses/LICENSE-2.0 * * * * Unless required by applicable law or agreed to in writing, software * * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/UploadedModuleDefinition.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/UploadedModuleDefinition.java index 65fa6d793..a8f0368e9 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/UploadedModuleDefinition.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/UploadedModuleDefinition.java @@ -6,7 +6,7 @@ * * you may not use this file except in compliance with the License. * * You may obtain a copy of the License at * * - * * http://www.apache.org/licenses/LICENSE-2.0 + * * https://www.apache.org/licenses/LICENSE-2.0 * * * * Unless required by applicable law or agreed to in writing, software * * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/WritableModuleRegistry.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/WritableModuleRegistry.java index 948818c72..2fdaa9e2e 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/WritableModuleRegistry.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/WritableModuleRegistry.java @@ -6,7 +6,7 @@ * * you may not use this file except in compliance with the License. * * You may obtain a copy of the License at * * - * * http://www.apache.org/licenses/LICENSE-2.0 + * * https://www.apache.org/licenses/LICENSE-2.0 * * * * Unless required by applicable law or agreed to in writing, software * * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/WritableResourceModuleRegistry.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/WritableResourceModuleRegistry.java index 398cd2adf..fb3cf9136 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/WritableResourceModuleRegistry.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/WritableResourceModuleRegistry.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/jmx/ModuleObjectNamingStrategy.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/jmx/ModuleObjectNamingStrategy.java index 74cb6955b..ab38125d1 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/jmx/ModuleObjectNamingStrategy.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/jmx/ModuleObjectNamingStrategy.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/store/ModuleMetadata.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/store/ModuleMetadata.java index b884acf91..534e952dc 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/store/ModuleMetadata.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/store/ModuleMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/store/ModuleMetadataRepository.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/store/ModuleMetadataRepository.java index 9e0af6e34..2fc2f6122 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/store/ModuleMetadataRepository.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/store/ModuleMetadataRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/store/ZooKeeperComposedModuleDefinitionRegistry.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/store/ZooKeeperComposedModuleDefinitionRegistry.java index 8f952f31a..8b4617bfd 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/store/ZooKeeperComposedModuleDefinitionRegistry.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/store/ZooKeeperComposedModuleDefinitionRegistry.java @@ -6,7 +6,7 @@ * * you may not use this file except in compliance with the License. * * You may obtain a copy of the License at * * - * * http://www.apache.org/licenses/LICENSE-2.0 + * * https://www.apache.org/licenses/LICENSE-2.0 * * * * Unless required by applicable law or agreed to in writing, software * * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/store/ZooKeeperModuleDependencyRepository.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/store/ZooKeeperModuleDependencyRepository.java index 243e571c8..97c2cd1b8 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/store/ZooKeeperModuleDependencyRepository.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/store/ZooKeeperModuleDependencyRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/store/ZooKeeperModuleMetadataRepository.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/store/ZooKeeperModuleMetadataRepository.java index 8fd2e08f2..f0f069f2c 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/store/ZooKeeperModuleMetadataRepository.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/store/ZooKeeperModuleMetadataRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/support/ModuleDefinitionRepositoryUtils.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/support/ModuleDefinitionRepositoryUtils.java index 847958cab..3b11b4fc2 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/support/ModuleDefinitionRepositoryUtils.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/support/ModuleDefinitionRepositoryUtils.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/support/ModuleDefinitionService.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/support/ModuleDefinitionService.java index 1ddf15985..086a9ef7e 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/support/ModuleDefinitionService.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/support/ModuleDefinitionService.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/support/ThreadContextClassLoaderSetterAdvice.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/support/ThreadContextClassLoaderSetterAdvice.java index 2e990a811..4c28a5676 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/support/ThreadContextClassLoaderSetterAdvice.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/module/support/ThreadContextClassLoaderSetterAdvice.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/AggregatorProcessorModuleOptionsMetadata.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/AggregatorProcessorModuleOptionsMetadata.java index 176052b3e..0d4f77a68 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/AggregatorProcessorModuleOptionsMetadata.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/AggregatorProcessorModuleOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FileAsRefMixin.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FileAsRefMixin.java index ebda915e6..5a2d3b4d8 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FileAsRefMixin.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FileAsRefMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FilePollHdfsJobOptionsMetadata.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FilePollHdfsJobOptionsMetadata.java index 7535ab6a0..4a9f3ab26 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FilePollHdfsJobOptionsMetadata.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FilePollHdfsJobOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FileReadingMode.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FileReadingMode.java index 1b74493a4..9b98e18d6 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FileReadingMode.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FileReadingMode.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FileSinkOptionsMetadata.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FileSinkOptionsMetadata.java index 84c1dbdc9..2ee280b66 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FileSinkOptionsMetadata.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FileSinkOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FileSourceOptionsMetadata.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FileSourceOptionsMetadata.java index 1609f9929..3e3ed22e9 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FileSourceOptionsMetadata.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FileSourceOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FtpHdfsJobOptionsMetadata.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FtpHdfsJobOptionsMetadata.java index 16e6fa519..5cbd898c8 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FtpHdfsJobOptionsMetadata.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FtpHdfsJobOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FtpSinkOptionsMetadata.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FtpSinkOptionsMetadata.java index 11b07656e..0b2c860d8 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FtpSinkOptionsMetadata.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FtpSinkOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FtpSourceOptionsMetadata.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FtpSourceOptionsMetadata.java index 2f46ffe90..bcdbf113e 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FtpSourceOptionsMetadata.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/FtpSourceOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/HdfsMongodbJobOptionsMetadata.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/HdfsMongodbJobOptionsMetadata.java index 2385824b9..7ec0d2254 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/HdfsMongodbJobOptionsMetadata.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/HdfsMongodbJobOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/HttpSourceOptionsMetadata.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/HttpSourceOptionsMetadata.java index 5d34d610e..1c04dd486 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/HttpSourceOptionsMetadata.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/HttpSourceOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/JmsSourceModuleOptionsMetadata.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/JmsSourceModuleOptionsMetadata.java index 148286eb5..446da68a8 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/JmsSourceModuleOptionsMetadata.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/JmsSourceModuleOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/LogSinkOptionsMetadata.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/LogSinkOptionsMetadata.java index 13b0e2422..63b1a75a8 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/LogSinkOptionsMetadata.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/LogSinkOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/MqttConnectionMixin.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/MqttConnectionMixin.java index f9a69e9d6..e2ba388b0 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/MqttConnectionMixin.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/MqttConnectionMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/MqttSinkOptionsMetadata.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/MqttSinkOptionsMetadata.java index cf70db514..bb20353b5 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/MqttSinkOptionsMetadata.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/MqttSinkOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/MqttSourceOptionsMetadata.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/MqttSourceOptionsMetadata.java index b0b89d875..d48d77d7b 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/MqttSourceOptionsMetadata.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/MqttSourceOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/RabbitConnectionMixin.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/RabbitConnectionMixin.java index 5392eb132..c7f7c0aeb 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/RabbitConnectionMixin.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/RabbitConnectionMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/RabbitSinkOptionsMetadata.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/RabbitSinkOptionsMetadata.java index e726ee1a2..0e2380286 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/RabbitSinkOptionsMetadata.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/RabbitSinkOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/RabbitSourceOptionsMetadata.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/RabbitSourceOptionsMetadata.java index 4e8bbb04f..df6aefa32 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/RabbitSourceOptionsMetadata.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/RabbitSourceOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/RedisConnectionMixin.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/RedisConnectionMixin.java index ed3019f50..13bdac982 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/RedisConnectionMixin.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/RedisConnectionMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/RedisSinkOptionsMetadata.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/RedisSinkOptionsMetadata.java index 8ea089afd..554062089 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/RedisSinkOptionsMetadata.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/RedisSinkOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/SftpSourceOptionsMetadata.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/SftpSourceOptionsMetadata.java index 11a64e6a6..f6854e1d8 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/SftpSourceOptionsMetadata.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/SftpSourceOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/SplitterProcessorOptionsMetadata.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/SplitterProcessorOptionsMetadata.java index a49a021e2..bcd3b5714 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/SplitterProcessorOptionsMetadata.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/SplitterProcessorOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/TailSourceOptionsMetadata.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/TailSourceOptionsMetadata.java index cb836f817..04e20a8aa 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/TailSourceOptionsMetadata.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/TailSourceOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/TimeSourceOptionsMetadata.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/TimeSourceOptionsMetadata.java index 6dc884938..8f10f5dad 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/TimeSourceOptionsMetadata.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/TimeSourceOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/TimestampFileJobOptionsMetadata.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/TimestampFileJobOptionsMetadata.java index 93ec7d058..b617005a9 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/TimestampFileJobOptionsMetadata.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/TimestampFileJobOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/TriggerSourceOptionsMetadata.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/TriggerSourceOptionsMetadata.java index ac3a23c49..17c1264d8 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/TriggerSourceOptionsMetadata.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/modules/metadata/TriggerSourceOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/AbstractJobPlugin.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/AbstractJobPlugin.java index ad8679363..584e69cba 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/AbstractJobPlugin.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/AbstractJobPlugin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/AbstractMessageBusBinderPlugin.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/AbstractMessageBusBinderPlugin.java index 821b9a00c..72fd7d8c7 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/AbstractMessageBusBinderPlugin.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/AbstractMessageBusBinderPlugin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/AbstractPlugin.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/AbstractPlugin.java index 5d9e33593..bb97d4b91 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/AbstractPlugin.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/AbstractPlugin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/AbstractStreamPlugin.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/AbstractStreamPlugin.java index 0e28f78cc..9d3dbdbc7 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/AbstractStreamPlugin.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/AbstractStreamPlugin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/ContainerInfoPlugin.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/ContainerInfoPlugin.java index 83080e894..d27f1619a 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/ContainerInfoPlugin.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/ContainerInfoPlugin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/MBeanExportingPlugin.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/MBeanExportingPlugin.java index 04fc912ea..c4e781756 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/MBeanExportingPlugin.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/MBeanExportingPlugin.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/ModuleConfigurationException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/ModuleConfigurationException.java index fc7f5b9bb..517f00847 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/ModuleConfigurationException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/ModuleConfigurationException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/ModuleInfoPlugin.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/ModuleInfoPlugin.java index b16d01364..5db437e8f 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/ModuleInfoPlugin.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/ModuleInfoPlugin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/PropertiesDecryptorPlugin.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/PropertiesDecryptorPlugin.java index cd4823654..22382222d 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/PropertiesDecryptorPlugin.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/PropertiesDecryptorPlugin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/ZookeeperConnectionPlugin.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/ZookeeperConnectionPlugin.java index 2445fe184..b83ef5db5 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/ZookeeperConnectionPlugin.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/ZookeeperConnectionPlugin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/BatchJobAlreadyExistsInRegistryException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/BatchJobAlreadyExistsInRegistryException.java index 02acd4547..eb2274900 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/BatchJobAlreadyExistsInRegistryException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/BatchJobAlreadyExistsInRegistryException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/BatchJobHeaders.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/BatchJobHeaders.java index a18d5e3a6..10897d4b9 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/BatchJobHeaders.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/BatchJobHeaders.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/BatchJobRegistryBeanPostProcessor.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/BatchJobRegistryBeanPostProcessor.java index 4981fdc08..895f854c7 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/BatchJobRegistryBeanPostProcessor.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/BatchJobRegistryBeanPostProcessor.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/DistributedJobLocator.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/DistributedJobLocator.java index 26705ceb2..da08dd089 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/DistributedJobLocator.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/DistributedJobLocator.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/DistributedJobService.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/DistributedJobService.java index 7c8e1a608..c5cb42818 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/DistributedJobService.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/DistributedJobService.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/ExpandedJobParametersConverter.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/ExpandedJobParametersConverter.java index deeeb51cd..40dc0d0ab 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/ExpandedJobParametersConverter.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/ExpandedJobParametersConverter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/JobEventsListenerPlugin.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/JobEventsListenerPlugin.java index 7d6124e1b..4a80bf1d1 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/JobEventsListenerPlugin.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/JobEventsListenerPlugin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/JobLaunchRequestTransformer.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/JobLaunchRequestTransformer.java index 355f52f04..5ea8ba4cc 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/JobLaunchRequestTransformer.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/JobLaunchRequestTransformer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/JobParametersBean.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/JobParametersBean.java index 9e7390eff..8950be100 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/JobParametersBean.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/JobParametersBean.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/JobPartitionerPlugin.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/JobPartitionerPlugin.java index e8933a2a7..ef5c04e58 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/JobPartitionerPlugin.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/JobPartitionerPlugin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/JobPlugin.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/JobPlugin.java index 26f00bd0e..8f96a0577 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/JobPlugin.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/JobPlugin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/JobPluginMetadataResolver.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/JobPluginMetadataResolver.java index 77ec260a1..eea2886b0 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/JobPluginMetadataResolver.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/JobPluginMetadataResolver.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/ModuleJobLauncher.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/ModuleJobLauncher.java index 5756d0d70..38ddf9563 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/ModuleJobLauncher.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/ModuleJobLauncher.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/ExecutionContextJacksonMixIn.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/ExecutionContextJacksonMixIn.java index dfd86a21e..95498fceb 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/ExecutionContextJacksonMixIn.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/ExecutionContextJacksonMixIn.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/JobLaunchingJobRepository.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/JobLaunchingJobRepository.java index 231751624..bf34cd6db 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/JobLaunchingJobRepository.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/JobLaunchingJobRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/JobLaunchingJobRepositoryFactoryBean.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/JobLaunchingJobRepositoryFactoryBean.java index 27caaa4c1..f3e19766c 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/JobLaunchingJobRepositoryFactoryBean.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/JobLaunchingJobRepositoryFactoryBean.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/StepExecutionJacksonMixIn.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/StepExecutionJacksonMixIn.java index 69de75517..fca756d44 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/StepExecutionJacksonMixIn.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/StepExecutionJacksonMixIn.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/BatchJobListener.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/BatchJobListener.java index 8e51cc314..412c27936 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/BatchJobListener.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/BatchJobListener.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/BatchListenerEventType.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/BatchListenerEventType.java index 6a8b5ebe9..f3b655d55 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/BatchListenerEventType.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/BatchListenerEventType.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/ChunkContextInfo.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/ChunkContextInfo.java index 0f53bb3b7..c48a732ce 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/ChunkContextInfo.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/ChunkContextInfo.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/FileDeletionStepExecutionListener.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/FileDeletionStepExecutionListener.java index 29b06421c..d834c706b 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/FileDeletionStepExecutionListener.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/FileDeletionStepExecutionListener.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/SimpleXdChunkListener.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/SimpleXdChunkListener.java index 9c9605255..010456dc5 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/SimpleXdChunkListener.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/SimpleXdChunkListener.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/SimpleXdItemListener.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/SimpleXdItemListener.java index 2eec2631f..2ddf94a75 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/SimpleXdItemListener.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/SimpleXdItemListener.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/SimpleXdJobExecutionListener.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/SimpleXdJobExecutionListener.java index f6ca107fd..3f403e5c0 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/SimpleXdJobExecutionListener.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/SimpleXdJobExecutionListener.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/SimpleXdSkipListener.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/SimpleXdSkipListener.java index 49cde9887..6343323e0 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/SimpleXdSkipListener.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/SimpleXdSkipListener.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/SimpleXdStepExecutionListener.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/SimpleXdStepExecutionListener.java index 899f8f708..75376d371 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/SimpleXdStepExecutionListener.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/SimpleXdStepExecutionListener.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/XDJobListenerConstants.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/XDJobListenerConstants.java index 4b2cd88e1..6a63f443b 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/XDJobListenerConstants.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/job/support/listener/XDJobListenerConstants.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/spark/streaming/LocalMessageBusHolder.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/spark/streaming/LocalMessageBusHolder.java index 88a226ce8..8fcd6f091 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/spark/streaming/LocalMessageBusHolder.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/spark/streaming/LocalMessageBusHolder.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/spark/streaming/MessageBusConfiguration.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/spark/streaming/MessageBusConfiguration.java index b4871dda3..9f5d6e7a1 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/spark/streaming/MessageBusConfiguration.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/spark/streaming/MessageBusConfiguration.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/spark/streaming/MessageBusReceiver.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/spark/streaming/MessageBusReceiver.java index 6ba4cd7c1..e75f3c9ee 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/spark/streaming/MessageBusReceiver.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/spark/streaming/MessageBusReceiver.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/spark/streaming/MessageBusSender.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/spark/streaming/MessageBusSender.java index cdddf8253..858e152ad 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/spark/streaming/MessageBusSender.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/spark/streaming/MessageBusSender.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/spark/streaming/SparkStreamingChannel.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/spark/streaming/SparkStreamingChannel.java index 841fa56ae..473965695 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/spark/streaming/SparkStreamingChannel.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/spark/streaming/SparkStreamingChannel.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/spark/streaming/SparkStreamingPlugin.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/spark/streaming/SparkStreamingPlugin.java index 0dfd62c24..a29338ac1 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/spark/streaming/SparkStreamingPlugin.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/spark/streaming/SparkStreamingPlugin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/stream/CustomMimeTypeConverter.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/stream/CustomMimeTypeConverter.java index ed5bebed8..d0f9ee065 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/stream/CustomMimeTypeConverter.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/stream/CustomMimeTypeConverter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/stream/ModuleTypeConversionPlugin.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/stream/ModuleTypeConversionPlugin.java index e43ec751b..8fba3b66c 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/stream/ModuleTypeConversionPlugin.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/stream/ModuleTypeConversionPlugin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/stream/ModuleTypeConversionPluginMetadataResolver.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/stream/ModuleTypeConversionPluginMetadataResolver.java index c5134c80b..e6df3def8 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/stream/ModuleTypeConversionPluginMetadataResolver.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/stream/ModuleTypeConversionPluginMetadataResolver.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/stream/ModuleTypeConversionSupport.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/stream/ModuleTypeConversionSupport.java index 9eb5a6963..8e9db63da 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/stream/ModuleTypeConversionSupport.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/stream/ModuleTypeConversionSupport.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/stream/StreamPlugin.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/stream/StreamPlugin.java index b780c40de..9cbb97eab 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/stream/StreamPlugin.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/plugins/stream/StreamPlugin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/AbstractBatchJobsController.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/AbstractBatchJobsController.java index 6c246e37a..99e087b47 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/AbstractBatchJobsController.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/AbstractBatchJobsController.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/AccessControlInterceptor.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/AccessControlInterceptor.java index fb07546cb..5495e9718 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/AccessControlInterceptor.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/AccessControlInterceptor.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/AdminController.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/AdminController.java index c12b10013..725de02bf 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/AdminController.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/AdminController.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/BatchJobExecutionsController.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/BatchJobExecutionsController.java index e6f5e5086..4298997fd 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/BatchJobExecutionsController.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/BatchJobExecutionsController.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/BatchJobInstancesController.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/BatchJobInstancesController.java index 9f5d86418..2e8856055 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/BatchJobInstancesController.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/BatchJobInstancesController.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/BatchJobsController.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/BatchJobsController.java index 6aa619a09..57d200021 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/BatchJobsController.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/BatchJobsController.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/BatchStepExecutionsController.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/BatchStepExecutionsController.java index 6b21ddfcc..cfbeca521 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/BatchStepExecutionsController.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/BatchStepExecutionsController.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/CompletionsController.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/CompletionsController.java index a37934e72..d226dcc8f 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/CompletionsController.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/CompletionsController.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/ContainersController.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/ContainersController.java index ac1d402db..90d86234b 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/ContainersController.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/ContainersController.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/DetailedJobInfoResourceAssembler.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/DetailedJobInfoResourceAssembler.java index bc93aa421..102d5c670 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/DetailedJobInfoResourceAssembler.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/DetailedJobInfoResourceAssembler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/DetailedModuleDefinitionResourceAssembler.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/DetailedModuleDefinitionResourceAssembler.java index 0d62011e3..9fc153ba9 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/DetailedModuleDefinitionResourceAssembler.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/DetailedModuleDefinitionResourceAssembler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/DocumentParseResultResourceAssembler.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/DocumentParseResultResourceAssembler.java index 6aee85716..5b4f82319 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/DocumentParseResultResourceAssembler.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/DocumentParseResultResourceAssembler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/JobDefinitionResourceAssembler.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/JobDefinitionResourceAssembler.java index 577fde310..59a9a3e1b 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/JobDefinitionResourceAssembler.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/JobDefinitionResourceAssembler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/JobExecutionInfoResourceAssembler.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/JobExecutionInfoResourceAssembler.java index 0b058ced7..51c2cefae 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/JobExecutionInfoResourceAssembler.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/JobExecutionInfoResourceAssembler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/JobInfoResourceAssembler.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/JobInfoResourceAssembler.java index 719e80b53..ec06542e1 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/JobInfoResourceAssembler.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/JobInfoResourceAssembler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/JobInstanceInfoResourceAssembler.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/JobInstanceInfoResourceAssembler.java index e428ae8dd..9eb17874c 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/JobInstanceInfoResourceAssembler.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/JobInstanceInfoResourceAssembler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/JobsController.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/JobsController.java index f260269d2..896fc5888 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/JobsController.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/JobsController.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/ModuleDefinitionResourceAssembler.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/ModuleDefinitionResourceAssembler.java index f71889f9e..d59885db6 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/ModuleDefinitionResourceAssembler.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/ModuleDefinitionResourceAssembler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/ModuleMetadataResourceAssembler.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/ModuleMetadataResourceAssembler.java index 56cd3dfb3..881ecc24b 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/ModuleMetadataResourceAssembler.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/ModuleMetadataResourceAssembler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/ModulesController.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/ModulesController.java index 8e00bafa6..dd57c1dde 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/ModulesController.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/ModulesController.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/ModulesMetadataController.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/ModulesMetadataController.java index 2be4ef0e3..d210bff46 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/ModulesMetadataController.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/ModulesMetadataController.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/PasswordUtils.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/PasswordUtils.java index e2823cd10..967ce79ba 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/PasswordUtils.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/PasswordUtils.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/RestConfiguration.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/RestConfiguration.java index 0d8180ab0..e0f1c4a73 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/RestConfiguration.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/RestConfiguration.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except * in compliance with the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License * is distributed on an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/RestControllerAdvice.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/RestControllerAdvice.java index dddd64815..ed2461702 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/RestControllerAdvice.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/RestControllerAdvice.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/RuntimeContainerResourceAssembler.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/RuntimeContainerResourceAssembler.java index 177b3fb1d..ec06cf3a1 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/RuntimeContainerResourceAssembler.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/RuntimeContainerResourceAssembler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/StepExecutionInfoResourceAssembler.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/StepExecutionInfoResourceAssembler.java index 6cace06fb..4f77601ff 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/StepExecutionInfoResourceAssembler.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/StepExecutionInfoResourceAssembler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/StepExecutionProgressInfoResourceAssembler.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/StepExecutionProgressInfoResourceAssembler.java index 192563a24..4d5f49448 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/StepExecutionProgressInfoResourceAssembler.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/StepExecutionProgressInfoResourceAssembler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/StreamDefinitionResourceAssembler.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/StreamDefinitionResourceAssembler.java index 606b99bf2..c7e276bfe 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/StreamDefinitionResourceAssembler.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/StreamDefinitionResourceAssembler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/StreamsController.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/StreamsController.java index 3b052503e..a3a7ddfbb 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/StreamsController.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/StreamsController.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/ToolsController.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/ToolsController.java index 25c87666c..4d7d962ab 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/ToolsController.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/ToolsController.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/XDController.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/XDController.java index 20465e7fd..d81b40d0a 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/XDController.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/XDController.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/XdErrorController.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/XdErrorController.java index 02435a5b6..259ae5cc5 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/XdErrorController.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/XdErrorController.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/meta/VersionController.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/meta/VersionController.java index cbe950649..d6af02791 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/meta/VersionController.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/meta/VersionController.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/AbstractMetricsController.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/AbstractMetricsController.java index fa2207fe1..164336d7b 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/AbstractMetricsController.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/AbstractMetricsController.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/AggregateCountersController.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/AggregateCountersController.java index 4ccf2b7f9..2870e3d0a 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/AggregateCountersController.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/AggregateCountersController.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/CountersController.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/CountersController.java index 5ad7de385..27bf56c5a 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/CountersController.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/CountersController.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/DeepAggregateCountResourceAssembler.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/DeepAggregateCountResourceAssembler.java index 899b06586..1eb1e6bf7 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/DeepAggregateCountResourceAssembler.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/DeepAggregateCountResourceAssembler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/DeepCounterResourceAssembler.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/DeepCounterResourceAssembler.java index a8691c09c..081db94e2 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/DeepCounterResourceAssembler.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/DeepCounterResourceAssembler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/DeepFieldValueCounterResourceAssembler.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/DeepFieldValueCounterResourceAssembler.java index 952cce000..a11276499 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/DeepFieldValueCounterResourceAssembler.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/DeepFieldValueCounterResourceAssembler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/DeepGaugeResourceAssembler.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/DeepGaugeResourceAssembler.java index c4c06b40a..fa9792fdc 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/DeepGaugeResourceAssembler.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/DeepGaugeResourceAssembler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/DeepRichGaugeResourceAssembler.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/DeepRichGaugeResourceAssembler.java index d53a35239..412c05cab 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/DeepRichGaugeResourceAssembler.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/DeepRichGaugeResourceAssembler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/FieldValueCountersController.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/FieldValueCountersController.java index 0babfd729..78f254cb7 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/FieldValueCountersController.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/FieldValueCountersController.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/GaugesController.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/GaugesController.java index 4ee7311a5..962ae60ae 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/GaugesController.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/GaugesController.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/RichGaugesController.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/RichGaugesController.java index f25300faf..9c8aa8989 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/RichGaugesController.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/RichGaugesController.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/ShallowMetricResourceAssembler.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/ShallowMetricResourceAssembler.java index b4e65e302..1c324a3c6 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/ShallowMetricResourceAssembler.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/metrics/ShallowMetricResourceAssembler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/security/SecurityController.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/security/SecurityController.java index 2c7d3dec9..f3df6389f 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/security/SecurityController.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/security/SecurityController.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/validation/ValidationController.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/validation/ValidationController.java index 1f12b0d5f..cdd31eb68 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/validation/ValidationController.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/rest/validation/ValidationController.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/ApplicationUtils.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/ApplicationUtils.java index bd6d14aa8..e1a61baf3 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/ApplicationUtils.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/ApplicationUtils.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/MessageBusClassLoaderFactory.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/MessageBusClassLoaderFactory.java index 56c4be709..c4e7cdc81 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/MessageBusClassLoaderFactory.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/MessageBusClassLoaderFactory.java @@ -6,7 +6,7 @@ * * you may not use this file except in compliance with the License. * * You may obtain a copy of the License at * * - * * http://www.apache.org/licenses/LICENSE-2.0 + * * https://www.apache.org/licenses/LICENSE-2.0 * * * * Unless required by applicable law or agreed to in writing, software * * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/MessageBusExtensionsConfiguration.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/MessageBusExtensionsConfiguration.java index acea3788c..2f99eebd8 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/MessageBusExtensionsConfiguration.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/MessageBusExtensionsConfiguration.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/ParentConfiguration.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/ParentConfiguration.java index ea56343f7..e2b847a09 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/ParentConfiguration.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/ParentConfiguration.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/SharedServerContextConfiguration.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/SharedServerContextConfiguration.java index 1bdfcc038..3f0ac09a9 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/SharedServerContextConfiguration.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/SharedServerContextConfiguration.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/AdminPortNotAvailableException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/AdminPortNotAvailableException.java index 1edbf9673..e578f7d6f 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/AdminPortNotAvailableException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/AdminPortNotAvailableException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/AdminServerApplication.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/AdminServerApplication.java index 994bf61c9..ef99ffe0d 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/AdminServerApplication.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/AdminServerApplication.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/ContainerMatcher.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/ContainerMatcher.java index dc7340c86..232a6ba0f 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/ContainerMatcher.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/ContainerMatcher.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DefaultDeploymentUnitStateCalculator.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DefaultDeploymentUnitStateCalculator.java index 9046b5311..5e9d5ba78 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DefaultDeploymentUnitStateCalculator.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DefaultDeploymentUnitStateCalculator.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DeploymentAction.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DeploymentAction.java index e46c98cbb..4020cd185 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DeploymentAction.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DeploymentAction.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DeploymentException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DeploymentException.java index 3d5cfc65c..f79e3d7da 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DeploymentException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DeploymentException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DeploymentHandler.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DeploymentHandler.java index b191d6eec..da35090e4 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DeploymentHandler.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DeploymentHandler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DeploymentMessage.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DeploymentMessage.java index bee6642d6..718aecc5a 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DeploymentMessage.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DeploymentMessage.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DeploymentMessagePublisher.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DeploymentMessagePublisher.java index 789d468b8..9bec133e6 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DeploymentMessagePublisher.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DeploymentMessagePublisher.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DeploymentUnitStateCalculator.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DeploymentUnitStateCalculator.java index 7a61d3eee..cf09f4bda 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DeploymentUnitStateCalculator.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DeploymentUnitStateCalculator.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DeploymentUnitType.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DeploymentUnitType.java index 2b028ddc6..975e817f3 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DeploymentUnitType.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/DeploymentUnitType.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/ModuleDeploymentPropertiesProvider.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/ModuleDeploymentPropertiesProvider.java index a4facba32..30a33ef58 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/ModuleDeploymentPropertiesProvider.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/ModuleDeploymentPropertiesProvider.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/ModuleDeploymentStatus.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/ModuleDeploymentStatus.java index b747945f8..e495bfdd3 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/ModuleDeploymentStatus.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/ModuleDeploymentStatus.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/RuntimeModuleDeploymentPropertiesProvider.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/RuntimeModuleDeploymentPropertiesProvider.java index da59cb162..18e818e5a 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/RuntimeModuleDeploymentPropertiesProvider.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/RuntimeModuleDeploymentPropertiesProvider.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/StreamRuntimePropertiesProvider.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/StreamRuntimePropertiesProvider.java index 4bc2b5183..3c1dcf271 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/StreamRuntimePropertiesProvider.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/StreamRuntimePropertiesProvider.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ContainerListener.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ContainerListener.java index 06a86f2aa..12c1db68c 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ContainerListener.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ContainerListener.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ContainerMatchingModuleRedeployer.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ContainerMatchingModuleRedeployer.java index caf8b9983..7ab47cf06 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ContainerMatchingModuleRedeployer.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ContainerMatchingModuleRedeployer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DefaultDeploymentStateRecalculator.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DefaultDeploymentStateRecalculator.java index 1dec0450e..c5365492f 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DefaultDeploymentStateRecalculator.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DefaultDeploymentStateRecalculator.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DefaultModuleDeploymentPropertiesProvider.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DefaultModuleDeploymentPropertiesProvider.java index e41f8b5e1..ae0230c57 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DefaultModuleDeploymentPropertiesProvider.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DefaultModuleDeploymentPropertiesProvider.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DepartedContainerModuleRedeployer.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DepartedContainerModuleRedeployer.java index 5346cccd7..5cb26a7a7 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DepartedContainerModuleRedeployer.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DepartedContainerModuleRedeployer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DeploymentConfiguration.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DeploymentConfiguration.java index b508323fa..cea57a8ee 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DeploymentConfiguration.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DeploymentConfiguration.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DeploymentLoader.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DeploymentLoader.java index 434d7a901..fac5bfaa7 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DeploymentLoader.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DeploymentLoader.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DeploymentMessageConsumer.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DeploymentMessageConsumer.java index b4b3d3466..e6e6c836f 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DeploymentMessageConsumer.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DeploymentMessageConsumer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DeploymentQueue.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DeploymentQueue.java index ba3cfc16e..5e9412425 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DeploymentQueue.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DeploymentQueue.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DeploymentSupervisor.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DeploymentSupervisor.java index 149bfe9df..6e15a5645 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DeploymentSupervisor.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/DeploymentSupervisor.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ModuleDeploymentWriter.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ModuleDeploymentWriter.java index fb5282027..d27d7b93b 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ModuleDeploymentWriter.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ModuleDeploymentWriter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ModuleRedeployer.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ModuleRedeployer.java index 8259bfac9..57e9e6de5 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ModuleRedeployer.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ModuleRedeployer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/SupervisorElectedEvent.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/SupervisorElectedEvent.java index a4b49a36b..90b3eb012 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/SupervisorElectedEvent.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/SupervisorElectedEvent.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/SupervisorElectionListener.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/SupervisorElectionListener.java index ae69bae6f..2d4dc8e9c 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/SupervisorElectionListener.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/SupervisorElectionListener.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ZKDeploymentHandler.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ZKDeploymentHandler.java index 3dcb152bf..f26b6cef8 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ZKDeploymentHandler.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ZKDeploymentHandler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ZKDeploymentMessagePublisher.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ZKDeploymentMessagePublisher.java index fcbe98568..7243a54c4 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ZKDeploymentMessagePublisher.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ZKDeploymentMessagePublisher.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ZKJobDeploymentHandler.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ZKJobDeploymentHandler.java index af9cc0552..d69296029 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ZKJobDeploymentHandler.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ZKJobDeploymentHandler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ZKStreamDeploymentHandler.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ZKStreamDeploymentHandler.java index 957015ed8..8db399db1 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ZKStreamDeploymentHandler.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/admin/deployment/zk/ZKStreamDeploymentHandler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/container/ContainerBootstrapConfiguration.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/container/ContainerBootstrapConfiguration.java index 68fdcbdc5..e6f0ae028 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/container/ContainerBootstrapConfiguration.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/container/ContainerBootstrapConfiguration.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/container/ContainerBootstrapContext.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/container/ContainerBootstrapContext.java index cb0891eaf..4af4a1870 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/container/ContainerBootstrapContext.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/container/ContainerBootstrapContext.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/container/ContainerConfiguration.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/container/ContainerConfiguration.java index ee7ecd67a..163219ebf 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/container/ContainerConfiguration.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/container/ContainerConfiguration.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/container/ContainerRegistrar.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/container/ContainerRegistrar.java index f8138e777..2cfebb31c 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/container/ContainerRegistrar.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/container/ContainerRegistrar.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/container/ContainerServerApplication.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/container/ContainerServerApplication.java index b138ac05e..0c4a22182 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/container/ContainerServerApplication.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/container/ContainerServerApplication.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/container/DeploymentListener.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/container/DeploymentListener.java index 6ec8b5fb8..81eaa19a5 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/container/DeploymentListener.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/container/DeploymentListener.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/AdminOptions.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/AdminOptions.java index df648d00b..512ecafa1 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/AdminOptions.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/AdminOptions.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/BeanPropertiesPropertySource.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/BeanPropertiesPropertySource.java index 94cc216ac..749605a1e 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/BeanPropertiesPropertySource.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/BeanPropertiesPropertySource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/CommandLinePropertySourceOverridingListener.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/CommandLinePropertySourceOverridingListener.java index e081e8a57..4ca725e30 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/CommandLinePropertySourceOverridingListener.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/CommandLinePropertySourceOverridingListener.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/CommonDistributedOptions.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/CommonDistributedOptions.java index 3bd814f5e..253f0b541 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/CommonDistributedOptions.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/CommonDistributedOptions.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/CommonOptions.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/CommonOptions.java index f1e6bf805..db51377da 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/CommonOptions.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/CommonOptions.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/ContainerOptions.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/ContainerOptions.java index d1faff347..da4a5428c 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/ContainerOptions.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/ContainerOptions.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/ResourcePatternScanningOptionHandler.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/ResourcePatternScanningOptionHandler.java index 2a90dcbcf..7813c3612 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/ResourcePatternScanningOptionHandler.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/ResourcePatternScanningOptionHandler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/ResourcePatternScanningOptionHandlers.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/ResourcePatternScanningOptionHandlers.java index b3af0a091..8fd07ac7e 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/ResourcePatternScanningOptionHandlers.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/ResourcePatternScanningOptionHandlers.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/SingleNodeOptions.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/SingleNodeOptions.java index a5def2e65..c1a3faa8c 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/SingleNodeOptions.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/options/SingleNodeOptions.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/security/FileAuthenticationConfiguration.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/security/FileAuthenticationConfiguration.java index edb9bf233..55ba1f6c7 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/security/FileAuthenticationConfiguration.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/security/FileAuthenticationConfiguration.java @@ -6,7 +6,7 @@ * * you may not use this file except in compliance with the License. * * You may obtain a copy of the License at * * - * * http://www.apache.org/licenses/LICENSE-2.0 + * * https://www.apache.org/licenses/LICENSE-2.0 * * * * Unless required by applicable law or agreed to in writing, software * * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/security/LdapAuthenticationConfiguration.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/security/LdapAuthenticationConfiguration.java index bf94507df..a8d7113ce 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/security/LdapAuthenticationConfiguration.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/security/LdapAuthenticationConfiguration.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/singlenode/SingleNodeApplication.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/singlenode/SingleNodeApplication.java index 5b2fb3b19..9e0e4958e 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/singlenode/SingleNodeApplication.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/server/singlenode/SingleNodeApplication.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/spark/SparkStreamingContainerFilter.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/spark/SparkStreamingContainerFilter.java index 77ca92920..71bccf812 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/spark/SparkStreamingContainerFilter.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/spark/SparkStreamingContainerFilter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/AbstractDeployer.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/AbstractDeployer.java index 1387b2123..fac70b1d4 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/AbstractDeployer.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/AbstractDeployer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/AbstractInstancePersistingDeployer.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/AbstractInstancePersistingDeployer.java index bbff27509..ec417788e 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/AbstractInstancePersistingDeployer.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/AbstractInstancePersistingDeployer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/AlreadyDeployedException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/AlreadyDeployedException.java index d3c0bd361..4ce696401 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/AlreadyDeployedException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/AlreadyDeployedException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/BaseInstance.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/BaseInstance.java index b7482570f..011efb9c1 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/BaseInstance.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/BaseInstance.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/DefinitionAlreadyExistsException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/DefinitionAlreadyExistsException.java index 34ce6df76..d6c11a537 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/DefinitionAlreadyExistsException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/DefinitionAlreadyExistsException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/DeploymentValidator.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/DeploymentValidator.java index 5c902f084..0e70c0aec 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/DeploymentValidator.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/DeploymentValidator.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/DocumentParseResult.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/DocumentParseResult.java index 332abbe2d..0a9c9b2a3 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/DocumentParseResult.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/DocumentParseResult.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/Job.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/Job.java index 90f98af71..d2922643a 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/Job.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/Job.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/JobDefinition.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/JobDefinition.java index 898fc8e36..ddfe7e263 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/JobDefinition.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/JobDefinition.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/JobDefinitionRepository.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/JobDefinitionRepository.java index 7548ae192..0f6c314ef 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/JobDefinitionRepository.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/JobDefinitionRepository.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/JobDeployer.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/JobDeployer.java index 5c20cfcec..0003d0acf 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/JobDeployer.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/JobDeployer.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/JobRepository.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/JobRepository.java index 641b15906..9f15914a0 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/JobRepository.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/JobRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/NoSuchDefinitionException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/NoSuchDefinitionException.java index 3ba9c43a8..d641d4af2 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/NoSuchDefinitionException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/NoSuchDefinitionException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/NotDeployedException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/NotDeployedException.java index b683296a8..d1f075431 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/NotDeployedException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/NotDeployedException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/ParsingContext.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/ParsingContext.java index ec5f21d00..a1ac9296f 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/ParsingContext.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/ParsingContext.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/Stream.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/Stream.java index 3d0f3e148..e6dfed39d 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/Stream.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/Stream.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/StreamDefinition.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/StreamDefinition.java index 82b1dc6d5..2989cef28 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/StreamDefinition.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/StreamDefinition.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/StreamDefinitionRepository.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/StreamDefinitionRepository.java index dada11748..8e6b3d040 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/StreamDefinitionRepository.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/StreamDefinitionRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/StreamDefinitionRepositoryUtils.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/StreamDefinitionRepositoryUtils.java index ff7bfab2e..e56eba133 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/StreamDefinitionRepositoryUtils.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/StreamDefinitionRepositoryUtils.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/StreamDeployer.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/StreamDeployer.java index 341f7139f..72dc393c0 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/StreamDeployer.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/StreamDeployer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/StreamException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/StreamException.java index 7ce94751f..b2949d744 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/StreamException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/StreamException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/StreamFactory.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/StreamFactory.java index b41cbde0c..6c7ee0e00 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/StreamFactory.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/StreamFactory.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/StreamRepository.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/StreamRepository.java index bcff3e46b..15b8c9ccf 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/StreamRepository.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/StreamRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/XDParser.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/XDParser.java index c213d5f3b..2cff2b6b8 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/XDParser.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/XDParser.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/XDStreamParser.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/XDStreamParser.java index d9b3e8c07..15a4fb0e9 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/XDStreamParser.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/XDStreamParser.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/AddModuleOptionsExpansionStrategy.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/AddModuleOptionsExpansionStrategy.java index 541bf8a0f..f4acf32cf 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/AddModuleOptionsExpansionStrategy.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/AddModuleOptionsExpansionStrategy.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/CompletionExpansionStrategy.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/CompletionExpansionStrategy.java index c22223369..54f79e540 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/CompletionExpansionStrategy.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/CompletionExpansionStrategy.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/CompletionProvider.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/CompletionProvider.java index 668464e98..b743bb602 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/CompletionProvider.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/CompletionProvider.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/CompletionRecoveryStrategy.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/CompletionRecoveryStrategy.java index 76fc0fa45..60e0b9ff4 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/CompletionRecoveryStrategy.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/CompletionRecoveryStrategy.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/EmptyStartYieldsModulesRecoveryStrategy.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/EmptyStartYieldsModulesRecoveryStrategy.java index afb00ad79..14f754da1 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/EmptyStartYieldsModulesRecoveryStrategy.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/EmptyStartYieldsModulesRecoveryStrategy.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/ExpandOneDashToTwoDashesRecoveryStrategy.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/ExpandOneDashToTwoDashesRecoveryStrategy.java index 253a114e8..3afa61897 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/ExpandOneDashToTwoDashesRecoveryStrategy.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/ExpandOneDashToTwoDashesRecoveryStrategy.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/ModulesAfterPipeRecoveryStrategy.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/ModulesAfterPipeRecoveryStrategy.java index 0a9058f41..a367624f8 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/ModulesAfterPipeRecoveryStrategy.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/ModulesAfterPipeRecoveryStrategy.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/OptionNameAfterDashDashRecoveryStrategy.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/OptionNameAfterDashDashRecoveryStrategy.java index 38af95cea..5d197195e 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/OptionNameAfterDashDashRecoveryStrategy.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/OptionNameAfterDashDashRecoveryStrategy.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/PipeIntoOtherModulesExpansionStrategy.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/PipeIntoOtherModulesExpansionStrategy.java index 4edbb9308..2283d3448 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/PipeIntoOtherModulesExpansionStrategy.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/PipeIntoOtherModulesExpansionStrategy.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/StacktraceFingerprintingCompletionRecoveryStrategy.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/StacktraceFingerprintingCompletionRecoveryStrategy.java index 220a287b3..7342d8ab8 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/StacktraceFingerprintingCompletionRecoveryStrategy.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/StacktraceFingerprintingCompletionRecoveryStrategy.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/UnfinishedModuleNameRecoveryStrategy.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/UnfinishedModuleNameRecoveryStrategy.java index 658fa4b2a..21fb6bbce 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/UnfinishedModuleNameRecoveryStrategy.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/UnfinishedModuleNameRecoveryStrategy.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/UnfinishedOptionNameRecoveryStrategy.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/UnfinishedOptionNameRecoveryStrategy.java index 48f06c63a..81d387b9f 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/UnfinishedOptionNameRecoveryStrategy.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/completion/UnfinishedOptionNameRecoveryStrategy.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/ArgumentNode.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/ArgumentNode.java index 79a2f582f..9b0cdf532 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/ArgumentNode.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/ArgumentNode.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/AstNode.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/AstNode.java index 4ed63b83c..892261a4a 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/AstNode.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/AstNode.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/ChannelNode.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/ChannelNode.java index 763f36b60..2a268669a 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/ChannelNode.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/ChannelNode.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/ChannelType.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/ChannelType.java index b0b3178ed..407c28258 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/ChannelType.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/ChannelType.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/CheckpointedStreamDefinitionException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/CheckpointedStreamDefinitionException.java index 83fbed0e1..340d34a24 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/CheckpointedStreamDefinitionException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/CheckpointedStreamDefinitionException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/LabelNode.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/LabelNode.java index ce8161920..fbb79b238 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/LabelNode.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/LabelNode.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/ModuleNode.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/ModuleNode.java index d7178e70a..cb0949634 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/ModuleNode.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/ModuleNode.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/SinkChannelNode.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/SinkChannelNode.java index 36e79bafa..7cbdfdbd0 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/SinkChannelNode.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/SinkChannelNode.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/SourceChannelNode.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/SourceChannelNode.java index e0ae18ad5..42cc28ec7 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/SourceChannelNode.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/SourceChannelNode.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/StreamConfigParser.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/StreamConfigParser.java index db54ab6f5..7a7e07775 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/StreamConfigParser.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/StreamConfigParser.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/StreamDefinitionException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/StreamDefinitionException.java index 58594919f..4635417b6 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/StreamDefinitionException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/StreamDefinitionException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/StreamLookupEnvironment.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/StreamLookupEnvironment.java index 44ca9d3a6..23f9324e0 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/StreamLookupEnvironment.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/StreamLookupEnvironment.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/StreamNode.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/StreamNode.java index c4bb22ae0..b57a0eb9a 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/StreamNode.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/StreamNode.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/Token.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/Token.java index 7823415e1..78e39b995 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/Token.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/Token.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/TokenKind.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/TokenKind.java index 60f52f6a5..d1fa28cf4 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/TokenKind.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/TokenKind.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/Tokenizer.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/Tokenizer.java index 532304d7e..b45e10e9b 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/Tokenizer.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/Tokenizer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/XDDSLMessages.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/XDDSLMessages.java index 8b809611c..b82de576a 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/XDDSLMessages.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/dsl/XDDSLMessages.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/zookeeper/RepositoryConnectionListener.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/zookeeper/RepositoryConnectionListener.java index b733b5da0..2484e3924 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/zookeeper/RepositoryConnectionListener.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/zookeeper/RepositoryConnectionListener.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/zookeeper/ZooKeeperJobDefinitionRepository.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/zookeeper/ZooKeeperJobDefinitionRepository.java index 9ff850f77..d389edbbb 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/zookeeper/ZooKeeperJobDefinitionRepository.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/zookeeper/ZooKeeperJobDefinitionRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/zookeeper/ZooKeeperJobRepository.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/zookeeper/ZooKeeperJobRepository.java index 26dac00ee..3baae5188 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/zookeeper/ZooKeeperJobRepository.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/zookeeper/ZooKeeperJobRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/zookeeper/ZooKeeperStreamDefinitionRepository.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/zookeeper/ZooKeeperStreamDefinitionRepository.java index 8391c3d2a..e428092c2 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/zookeeper/ZooKeeperStreamDefinitionRepository.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/zookeeper/ZooKeeperStreamDefinitionRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/zookeeper/ZooKeeperStreamRepository.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/zookeeper/ZooKeeperStreamRepository.java index 623d48868..fbfc135be 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/zookeeper/ZooKeeperStreamRepository.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/stream/zookeeper/ZooKeeperStreamRepository.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/AbstractSingleNodeNamedChannelModule.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/AbstractSingleNodeNamedChannelModule.java index ceb011839..4724af7bb 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/AbstractSingleNodeNamedChannelModule.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/AbstractSingleNodeNamedChannelModule.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/AbstractSingleNodeNamedChannelModuleFactory.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/AbstractSingleNodeNamedChannelModuleFactory.java index 763b3c11b..39fde1a60 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/AbstractSingleNodeNamedChannelModuleFactory.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/AbstractSingleNodeNamedChannelModuleFactory.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/NamedChannelModule.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/NamedChannelModule.java index acf52b004..121c23542 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/NamedChannelModule.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/NamedChannelModule.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/ResourceStateVerifier.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/ResourceStateVerifier.java index b59cfba72..9348b15eb 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/ResourceStateVerifier.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/ResourceStateVerifier.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/SingleNodeIntegrationTestSupport.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/SingleNodeIntegrationTestSupport.java index 6aa37e2fe..c7f1e0c58 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/SingleNodeIntegrationTestSupport.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/SingleNodeIntegrationTestSupport.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/SingletonModuleRegistry.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/SingletonModuleRegistry.java index fc617fda8..3cb1997a2 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/SingletonModuleRegistry.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/SingletonModuleRegistry.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/process/AbstractSingleNodeProcessingChain.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/process/AbstractSingleNodeProcessingChain.java index 0d05fb71d..b397578fa 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/process/AbstractSingleNodeProcessingChain.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/process/AbstractSingleNodeProcessingChain.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/process/SingleNodeProcessingChain.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/process/SingleNodeProcessingChain.java index ac0385328..16f3ac906 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/process/SingleNodeProcessingChain.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/process/SingleNodeProcessingChain.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/process/SingleNodeProcessingChainConsumer.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/process/SingleNodeProcessingChainConsumer.java index 07479cf99..220e7acc1 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/process/SingleNodeProcessingChainConsumer.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/process/SingleNodeProcessingChainConsumer.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/process/SingleNodeProcessingChainProducer.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/process/SingleNodeProcessingChainProducer.java index 17c5f8ed0..fe07371a9 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/process/SingleNodeProcessingChainProducer.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/process/SingleNodeProcessingChainProducer.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/process/SingleNodeProcessingChainSupport.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/process/SingleNodeProcessingChainSupport.java index c6594293d..1357ba78d 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/process/SingleNodeProcessingChainSupport.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/process/SingleNodeProcessingChainSupport.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/sink/AbstractSingleNodeNamedChannelSink.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/sink/AbstractSingleNodeNamedChannelSink.java index ea26bd74f..9112d1473 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/sink/AbstractSingleNodeNamedChannelSink.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/sink/AbstractSingleNodeNamedChannelSink.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/sink/NamedChannelSink.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/sink/NamedChannelSink.java index 8fb74ba06..18006237f 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/sink/NamedChannelSink.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/sink/NamedChannelSink.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/sink/SingleNodeNamedChannelSinkFactory.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/sink/SingleNodeNamedChannelSinkFactory.java index ffa75de2a..1661c3b69 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/sink/SingleNodeNamedChannelSinkFactory.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/sink/SingleNodeNamedChannelSinkFactory.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/sink/SingleNodeNamedQueueSink.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/sink/SingleNodeNamedQueueSink.java index 3320aee14..2918e9814 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/sink/SingleNodeNamedQueueSink.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/sink/SingleNodeNamedQueueSink.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/sink/SingleNodeNamedTopicSink.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/sink/SingleNodeNamedTopicSink.java index f406753af..90595c81d 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/sink/SingleNodeNamedTopicSink.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/sink/SingleNodeNamedTopicSink.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/source/AbstractSingleNodeNamedChannelSource.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/source/AbstractSingleNodeNamedChannelSource.java index 96695ff3d..7bcff0725 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/source/AbstractSingleNodeNamedChannelSource.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/source/AbstractSingleNodeNamedChannelSource.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/source/NamedChannelSource.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/source/NamedChannelSource.java index cf66f8cec..6d70fdfc4 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/source/NamedChannelSource.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/source/NamedChannelSource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/source/SingleNodeNamedChannelSourceFactory.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/source/SingleNodeNamedChannelSourceFactory.java index 07cc6486a..996105fd6 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/source/SingleNodeNamedChannelSourceFactory.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/source/SingleNodeNamedChannelSourceFactory.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/source/SingleNodeNamedQueueSource.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/source/SingleNodeNamedQueueSource.java index 0112f5cd0..f8eeae758 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/source/SingleNodeNamedQueueSource.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/source/SingleNodeNamedQueueSource.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/source/SingleNodeNamedTopicSource.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/source/SingleNodeNamedTopicSource.java index 143b06ac0..4b675369a 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/source/SingleNodeNamedTopicSource.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/test/source/SingleNodeNamedTopicSource.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/BannerUtils.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/BannerUtils.java index b5e38b733..4c9ebb04c 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/BannerUtils.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/BannerUtils.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/ConfigLocations.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/ConfigLocations.java index 54837e684..1f469e706 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/ConfigLocations.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/ConfigLocations.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/DeploymentPropertiesUtility.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/DeploymentPropertiesUtility.java index c5acb6b6b..eecdb7540 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/DeploymentPropertiesUtility.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/DeploymentPropertiesUtility.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/PageNotFoundException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/PageNotFoundException.java index e9069d274..a41567c69 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/PageNotFoundException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/PageNotFoundException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/PagingUtility.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/PagingUtility.java index a476eb1ed..6f0e70c33 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/PagingUtility.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/PagingUtility.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/RuntimeUtils.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/RuntimeUtils.java index 55c628e76..93474da8d 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/RuntimeUtils.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/RuntimeUtils.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/XdConfigLoggingInitializer.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/XdConfigLoggingInitializer.java index f489d624f..cc3f0a574 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/XdConfigLoggingInitializer.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/XdConfigLoggingInitializer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/XdProfiles.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/XdProfiles.java index aec286b70..5789894d3 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/XdProfiles.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/XdProfiles.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/XdUtils.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/XdUtils.java index 03c5cbbde..eb2ede0c1 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/XdUtils.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/XdUtils.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/logging/CustomLoggerConverter.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/logging/CustomLoggerConverter.java index bfc2f25a0..801efcb62 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/logging/CustomLoggerConverter.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/logging/CustomLoggerConverter.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/logging/LoggerAbbreviator.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/logging/LoggerAbbreviator.java index cac068b5d..af5064723 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/logging/LoggerAbbreviator.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/logging/LoggerAbbreviator.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/logging/VersionPatternConverter.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/logging/VersionPatternConverter.java index c7854e6e7..c627d1787 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/logging/VersionPatternConverter.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/logging/VersionPatternConverter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/logging/VersionPatternLayout.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/logging/VersionPatternLayout.java index 18a530677..35129d046 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/logging/VersionPatternLayout.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/logging/VersionPatternLayout.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/logging/VersionPatternParser.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/logging/VersionPatternParser.java index b4ff70bdb..b6bfd8275 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/logging/VersionPatternParser.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/util/logging/VersionPatternParser.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/ChildPathIterator.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/ChildPathIterator.java index 77540e45f..472a6b2ef 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/ChildPathIterator.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/ChildPathIterator.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/EmbeddedZooKeeper.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/EmbeddedZooKeeper.java index 2ad90fe5a..b62edefdf 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/EmbeddedZooKeeper.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/EmbeddedZooKeeper.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/Paths.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/Paths.java index fb5062e8f..0073308b5 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/Paths.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/Paths.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/ZooKeeperAccessException.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/ZooKeeperAccessException.java index 02cc57d94..8adea4351 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/ZooKeeperAccessException.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/ZooKeeperAccessException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/ZooKeeperConnection.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/ZooKeeperConnection.java index 6843504c7..2c3d36c38 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/ZooKeeperConnection.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/ZooKeeperConnection.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/ZooKeeperConnectionConfigurer.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/ZooKeeperConnectionConfigurer.java index 4668dcb16..02321d86b 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/ZooKeeperConnectionConfigurer.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/ZooKeeperConnectionConfigurer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/ZooKeeperConnectionListener.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/ZooKeeperConnectionListener.java index 56776d5c0..4a072daa1 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/ZooKeeperConnectionListener.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/ZooKeeperConnectionListener.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/ZooKeeperUtils.java b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/ZooKeeperUtils.java index c19f30a7d..5faac9e2b 100644 --- a/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/ZooKeeperUtils.java +++ b/spring-xd-dirt/src/main/java/org/springframework/xd/dirt/zookeeper/ZooKeeperUtils.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/AdhocTestSuite.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/AdhocTestSuite.java index e7fe0f99e..e55819442 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/AdhocTestSuite.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/AdhocTestSuite.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/batch/RuntimeBatchConfigurerIntegrationTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/batch/RuntimeBatchConfigurerIntegrationTests.java index abdd9a80c..2f52b3f15 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/batch/RuntimeBatchConfigurerIntegrationTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/batch/RuntimeBatchConfigurerIntegrationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/batch/RuntimeBatchConfigurerTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/batch/RuntimeBatchConfigurerTests.java index 826d65fb3..cd30ad758 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/batch/RuntimeBatchConfigurerTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/batch/RuntimeBatchConfigurerTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/batch/tasklet/JobLaunchingTaskletTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/batch/tasklet/JobLaunchingTaskletTests.java index 511d33160..b1d181a45 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/batch/tasklet/JobLaunchingTaskletTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/batch/tasklet/JobLaunchingTaskletTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/config/AbstractSingleNodeInitializationTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/config/AbstractSingleNodeInitializationTests.java index b32d84f7a..e745eb0cf 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/config/AbstractSingleNodeInitializationTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/config/AbstractSingleNodeInitializationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/config/LocalSingleNodeInitializationTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/config/LocalSingleNodeInitializationTests.java index 57924627d..78129d005 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/config/LocalSingleNodeInitializationTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/config/LocalSingleNodeInitializationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/config/RabbitSingleNodeInitializationTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/config/RabbitSingleNodeInitializationTests.java index 80ce03503..f2f2dcc02 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/config/RabbitSingleNodeInitializationTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/config/RabbitSingleNodeInitializationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/config/RedisSingleNodeInitializationTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/config/RedisSingleNodeInitializationTests.java index 7dfdb0f3a..bf14bf5ef 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/config/RedisSingleNodeInitializationTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/config/RedisSingleNodeInitializationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/config/TestMessageBusInjection.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/config/TestMessageBusInjection.java index a9d0d4c00..71f6959dc 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/config/TestMessageBusInjection.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/config/TestMessageBusInjection.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/config/ZooKeeperConnectionConfiguration.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/config/ZooKeeperConnectionConfiguration.java index 53f0ea8ae..07f2ee3c9 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/config/ZooKeeperConnectionConfiguration.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/config/ZooKeeperConnectionConfiguration.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/config/ZookeeperClientConnectTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/config/ZookeeperClientConnectTests.java index 9b0bad36e..ac59aa91b 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/config/ZookeeperClientConnectTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/config/ZookeeperClientConnectTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/container/store/ZooKeeperAdminRepositoryTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/container/store/ZooKeeperAdminRepositoryTests.java index 70ba04aac..0e1698718 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/container/store/ZooKeeperAdminRepositoryTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/container/store/ZooKeeperAdminRepositoryTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/core/ModuleDeploymentsPathTest.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/core/ModuleDeploymentsPathTest.java index 61684a91d..2d2885b10 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/core/ModuleDeploymentsPathTest.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/core/ModuleDeploymentsPathTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/core/StreamDeploymentsPathTest.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/core/StreamDeploymentsPathTest.java index bdcd65517..e921ab0f5 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/core/StreamDeploymentsPathTest.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/core/StreamDeploymentsPathTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/AbstractMessageBusTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/AbstractMessageBusTests.java index 6415bf4d7..682a1db28 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/AbstractMessageBusTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/AbstractMessageBusTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/AbstractTestMessageBus.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/AbstractTestMessageBus.java index 3db9fdb9a..d7fa4c0cf 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/AbstractTestMessageBus.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/AbstractTestMessageBus.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/BrokerBusTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/BrokerBusTests.java index 7cb9ff7bb..0474299f1 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/BrokerBusTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/BrokerBusTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/MessageBusAwareChannelResolverTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/MessageBusAwareChannelResolverTests.java index 7dbbaf958..0a18c9b2b 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/MessageBusAwareChannelResolverTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/MessageBusAwareChannelResolverTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/MessageBusSupportTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/MessageBusSupportTests.java index 6a6a40fe9..5faea208f 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/MessageBusSupportTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/MessageBusSupportTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/PartitionCapableBusTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/PartitionCapableBusTests.java index cca71c7bf..9c35182b6 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/PartitionCapableBusTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/PartitionCapableBusTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/PartitionTestSupport.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/PartitionTestSupport.java index fbd982a01..14bd4588c 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/PartitionTestSupport.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/PartitionTestSupport.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/converter/FromMessageConverterTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/converter/FromMessageConverterTests.java index 0c8dfa062..69b4df717 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/converter/FromMessageConverterTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/converter/FromMessageConverterTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/kafka/KafkaMessageBusTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/kafka/KafkaMessageBusTests.java index 9f953d01c..ed5a7961a 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/kafka/KafkaMessageBusTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/kafka/KafkaMessageBusTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/kafka/KafkaTestMessageBus.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/kafka/KafkaTestMessageBus.java index 06d529d8c..397b1ab23 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/kafka/KafkaTestMessageBus.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/kafka/KafkaTestMessageBus.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/kafka/RawKafkaPartitionTestSupport.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/kafka/RawKafkaPartitionTestSupport.java index 37d93f2cd..b13d572a6 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/kafka/RawKafkaPartitionTestSupport.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/kafka/RawKafkaPartitionTestSupport.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/kafka/RawModeKafkaMessageBusTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/kafka/RawModeKafkaMessageBusTests.java index 4b2893d16..d8d5e6016 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/kafka/RawModeKafkaMessageBusTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/kafka/RawModeKafkaMessageBusTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/local/LocalMessageBusTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/local/LocalMessageBusTests.java index 7cc888bb2..88cf38f0c 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/local/LocalMessageBusTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/local/LocalMessageBusTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/rabbit/RabbitBusCleanerTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/rabbit/RabbitBusCleanerTests.java index 2218e83fa..9754c49a0 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/rabbit/RabbitBusCleanerTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/rabbit/RabbitBusCleanerTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/rabbit/RabbitMessageBusTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/rabbit/RabbitMessageBusTests.java index b25658e78..a3b90f6c7 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/rabbit/RabbitMessageBusTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/rabbit/RabbitMessageBusTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/rabbit/RabbitTestMessageBus.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/rabbit/RabbitTestMessageBus.java index 69567f4c7..278d93823 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/rabbit/RabbitTestMessageBus.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/rabbit/RabbitTestMessageBus.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/redis/RedisMessageBusTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/redis/RedisMessageBusTests.java index 7a5097ed7..9e3d51c46 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/redis/RedisMessageBusTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/redis/RedisMessageBusTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/redis/RedisTestMessageBus.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/redis/RedisTestMessageBus.java index 1c3741c7e..ecc0730c1 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/redis/RedisTestMessageBus.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/bus/redis/RedisTestMessageBus.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/kafka/TestKafkaCluster.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/kafka/TestKafkaCluster.java index c2a74969a..30adb3352 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/kafka/TestKafkaCluster.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/kafka/TestKafkaCluster.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/redis/AbstractRedisSerializerTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/redis/AbstractRedisSerializerTests.java index cd94eafd1..a86c27ea6 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/redis/AbstractRedisSerializerTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/redis/AbstractRedisSerializerTests.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/redis/RedisPublishingMessageHandlerTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/redis/RedisPublishingMessageHandlerTests.java index fdc653870..87c8d133a 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/redis/RedisPublishingMessageHandlerTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/redis/RedisPublishingMessageHandlerTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/redis/RedisQueueInboundChannelAdapterTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/redis/RedisQueueInboundChannelAdapterTests.java index d45c9f654..10bbe15f7 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/redis/RedisQueueInboundChannelAdapterTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/redis/RedisQueueInboundChannelAdapterTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/redis/RedisQueueOutboundChannelAdapterTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/redis/RedisQueueOutboundChannelAdapterTests.java index 92cb613f3..6999e4e62 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/redis/RedisQueueOutboundChannelAdapterTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/integration/redis/RedisQueueOutboundChannelAdapterTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/jms/AmqBrokerAndTest.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/jms/AmqBrokerAndTest.java index 9bc7c5e96..2489ba87e 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/jms/AmqBrokerAndTest.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/jms/AmqBrokerAndTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/job/StepExecutionInfoTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/job/StepExecutionInfoTests.java index 7e34ac6eb..951da2a4c 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/job/StepExecutionInfoTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/job/StepExecutionInfoTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/job/dsl/JobParserTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/job/dsl/JobParserTests.java index d538ef9c0..71c9d14fd 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/job/dsl/JobParserTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/job/dsl/JobParserTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/listener/ZooKeeperContainerRepositoryTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/listener/ZooKeeperContainerRepositoryTests.java index ac8e9dd95..9246c7fa8 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/listener/ZooKeeperContainerRepositoryTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/listener/ZooKeeperContainerRepositoryTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/CompositeModuleTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/CompositeModuleTests.java index b133733b4..7b76efb9a 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/CompositeModuleTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/CompositeModuleTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/DelegatingModuleRegistryTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/DelegatingModuleRegistryTests.java index 91d585b82..8172ee706 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/DelegatingModuleRegistryTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/DelegatingModuleRegistryTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/ModuleDefinitionMatchers.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/ModuleDefinitionMatchers.java index a42b5a1d1..24d0d8eb2 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/ModuleDefinitionMatchers.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/ModuleDefinitionMatchers.java @@ -6,7 +6,7 @@ * * you may not use this file except in compliance with the License. * * You may obtain a copy of the License at * * - * * http://www.apache.org/licenses/LICENSE-2.0 + * * https://www.apache.org/licenses/LICENSE-2.0 * * * * Unless required by applicable law or agreed to in writing, software * * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/ResourceModuleRegistryTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/ResourceModuleRegistryTests.java index eff770bdb..adaf6e22f 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/ResourceModuleRegistryTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/ResourceModuleRegistryTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/SingletonModuleRegistryTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/SingletonModuleRegistryTests.java index d0ee9447a..367cb45bc 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/SingletonModuleRegistryTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/SingletonModuleRegistryTests.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/SynchronizingModuleRegistryTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/SynchronizingModuleRegistryTests.java index df596d4a9..fff80e054 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/SynchronizingModuleRegistryTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/SynchronizingModuleRegistryTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/TestModuleEventListener.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/TestModuleEventListener.java index 8ed54049e..471db5464 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/TestModuleEventListener.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/TestModuleEventListener.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/WritableResourceModuleRegistryLogicTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/WritableResourceModuleRegistryLogicTests.java index 3da44f4c7..c6370aba5 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/WritableResourceModuleRegistryLogicTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/WritableResourceModuleRegistryLogicTests.java @@ -6,7 +6,7 @@ * * you may not use this file except in compliance with the License. * * You may obtain a copy of the License at * * - * * http://www.apache.org/licenses/LICENSE-2.0 + * * https://www.apache.org/licenses/LICENSE-2.0 * * * * Unless required by applicable law or agreed to in writing, software * * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/jmx/ModuleObjectNamingStrategyTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/jmx/ModuleObjectNamingStrategyTests.java index 8dc99fa93..a137a93b4 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/jmx/ModuleObjectNamingStrategyTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/module/jmx/ModuleObjectNamingStrategyTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/modules/metadata/InputTypeTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/modules/metadata/InputTypeTests.java index 5b7a4019b..735202640 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/modules/metadata/InputTypeTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/modules/metadata/InputTypeTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/modules/metadata/ModuleOptionsMetadataSanityTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/modules/metadata/ModuleOptionsMetadataSanityTests.java index 90364f74a..68868e3f0 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/modules/metadata/ModuleOptionsMetadataSanityTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/modules/metadata/ModuleOptionsMetadataSanityTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/modules/metadata/TestTupleProcessorOptionsMetadata.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/modules/metadata/TestTupleProcessorOptionsMetadata.java index 46fba0dd3..376789ad4 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/modules/metadata/TestTupleProcessorOptionsMetadata.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/modules/metadata/TestTupleProcessorOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/ModuleDeploymentTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/ModuleDeploymentTests.java index 31c2639c6..1c257df2c 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/ModuleDeploymentTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/ModuleDeploymentTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/ExpandedJobParametersConverterTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/ExpandedJobParametersConverterTests.java index a4b7878a3..a59b1aacc 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/ExpandedJobParametersConverterTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/ExpandedJobParametersConverterTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/JobLaunchRequestTransformerTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/JobLaunchRequestTransformerTests.java index c03f9e18c..c782708b4 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/JobLaunchRequestTransformerTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/JobLaunchRequestTransformerTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/JobParametersBeanTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/JobParametersBeanTests.java index daa6a700b..a69badafc 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/JobParametersBeanTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/JobParametersBeanTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/JobPluginTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/JobPluginTests.java index 9c29a63a9..51b68f5d9 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/JobPluginTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/JobPluginTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/JobRepoTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/JobRepoTests.java index 46dd7774d..b9351629d 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/JobRepoTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/JobRepoTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/RabbitJobPluginTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/RabbitJobPluginTests.java index c73e5eb19..be338d881 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/RabbitJobPluginTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/RabbitJobPluginTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/RedisJobPluginTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/RedisJobPluginTests.java index 8e5e1b047..c5cd17f04 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/RedisJobPluginTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/RedisJobPluginTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/support/JobLaunchingJobRepositoryTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/support/JobLaunchingJobRepositoryTests.java index 7c7babca9..53ad99488 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/support/JobLaunchingJobRepositoryTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/support/JobLaunchingJobRepositoryTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/support/JobSupport.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/support/JobSupport.java index f87d63b47..456e88894 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/support/JobSupport.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/support/JobSupport.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/support/StepExecutionJacksonMixInTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/support/StepExecutionJacksonMixInTests.java index abecf255d..6c07a1441 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/support/StepExecutionJacksonMixInTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/support/StepExecutionJacksonMixInTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/support/StepSupport.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/support/StepSupport.java index b19ab4d44..8fd3078e7 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/support/StepSupport.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/job/support/StepSupport.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/stream/MessageBusRegistrationTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/stream/MessageBusRegistrationTests.java index 36d26c674..e43781481 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/stream/MessageBusRegistrationTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/stream/MessageBusRegistrationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/stream/StreamPluginTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/stream/StreamPluginTests.java index 8942559ac..68338ff24 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/stream/StreamPluginTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/plugins/stream/StreamPluginTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/AbstractControllerIntegrationTest.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/AbstractControllerIntegrationTest.java index 7ba533cf1..8261b75cd 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/AbstractControllerIntegrationTest.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/AbstractControllerIntegrationTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/BatchJobExecutionsControllerIntegrationTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/BatchJobExecutionsControllerIntegrationTests.java index e5c8b6eb3..f74939de1 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/BatchJobExecutionsControllerIntegrationTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/BatchJobExecutionsControllerIntegrationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/BatchJobInstancesControllerIntegrationTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/BatchJobInstancesControllerIntegrationTests.java index 92db5bb5b..f7855bf6a 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/BatchJobInstancesControllerIntegrationTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/BatchJobInstancesControllerIntegrationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/BatchJobsControllerIntegrationTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/BatchJobsControllerIntegrationTests.java index 921cb3254..3f7fb9e70 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/BatchJobsControllerIntegrationTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/BatchJobsControllerIntegrationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/BatchStepExecutionsControllerIntegrationTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/BatchStepExecutionsControllerIntegrationTests.java index 28704b551..c1c7d16be 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/BatchStepExecutionsControllerIntegrationTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/BatchStepExecutionsControllerIntegrationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/ContainersControllerIntegrationTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/ContainersControllerIntegrationTests.java index d3d427a89..4ca2d1869 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/ContainersControllerIntegrationTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/ContainersControllerIntegrationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/Dependencies.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/Dependencies.java index 1641047c6..86daf0e81 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/Dependencies.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/Dependencies.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/JobsControllerIntegrationTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/JobsControllerIntegrationTests.java index 747b6dece..d246c840c 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/JobsControllerIntegrationTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/JobsControllerIntegrationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/JobsControllerIntegrationTestsConfig.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/JobsControllerIntegrationTestsConfig.java index 390205778..896519ec6 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/JobsControllerIntegrationTestsConfig.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/JobsControllerIntegrationTestsConfig.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/ModuleMetadataControllerIntegrationTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/ModuleMetadataControllerIntegrationTests.java index 46f1f96ae..1a816681b 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/ModuleMetadataControllerIntegrationTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/ModuleMetadataControllerIntegrationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/ModulesControllerIntegrationTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/ModulesControllerIntegrationTests.java index d71b21f06..6ce4d6460 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/ModulesControllerIntegrationTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/ModulesControllerIntegrationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/PasswordUtilsTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/PasswordUtilsTests.java index 18d383db7..3fb0a1d9b 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/PasswordUtilsTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/PasswordUtilsTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/StreamsControllerIntegrationWithRepositoryTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/StreamsControllerIntegrationWithRepositoryTests.java index f191cbcde..f82182766 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/StreamsControllerIntegrationWithRepositoryTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/StreamsControllerIntegrationWithRepositoryTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/StreamsControllerIntegrationWithRepositoryTestsConfig.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/StreamsControllerIntegrationWithRepositoryTestsConfig.java index d7fac8156..17fa12f9f 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/StreamsControllerIntegrationWithRepositoryTestsConfig.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/StreamsControllerIntegrationWithRepositoryTestsConfig.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/meta/VersionControllerIntegrationTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/meta/VersionControllerIntegrationTests.java index 7e355ea6b..cef06ea62 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/meta/VersionControllerIntegrationTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/meta/VersionControllerIntegrationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/metrics/AggregateCountersControllerIntegrationTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/metrics/AggregateCountersControllerIntegrationTests.java index 703228c2d..9b948c1b6 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/metrics/AggregateCountersControllerIntegrationTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/metrics/AggregateCountersControllerIntegrationTests.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/metrics/CountersControllerIntegrationTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/metrics/CountersControllerIntegrationTests.java index 84adeeeba..62887025f 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/metrics/CountersControllerIntegrationTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/metrics/CountersControllerIntegrationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/metrics/FieldValueCountersControllerIntegrationTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/metrics/FieldValueCountersControllerIntegrationTests.java index d4a768b29..baa42b18d 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/metrics/FieldValueCountersControllerIntegrationTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/metrics/FieldValueCountersControllerIntegrationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/metrics/GaugeControllerIntegrationTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/metrics/GaugeControllerIntegrationTests.java index e9bb2f270..37d008730 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/metrics/GaugeControllerIntegrationTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/metrics/GaugeControllerIntegrationTests.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/metrics/RichGaugeControllerIntegrationTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/metrics/RichGaugeControllerIntegrationTests.java index 73730f632..f2988dd50 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/metrics/RichGaugeControllerIntegrationTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/metrics/RichGaugeControllerIntegrationTests.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/security/SecurityControllerIntegrationTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/security/SecurityControllerIntegrationTests.java index 46aa259c7..ab4f344b0 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/security/SecurityControllerIntegrationTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/security/SecurityControllerIntegrationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/security/SecurityControllerIntegrationTestsInitializer.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/security/SecurityControllerIntegrationTestsInitializer.java index 671bcf753..ef5819869 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/security/SecurityControllerIntegrationTestsInitializer.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/security/SecurityControllerIntegrationTestsInitializer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/validation/ValidationControllerIntegrationTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/validation/ValidationControllerIntegrationTests.java index 31988b2bb..96b7a975f 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/validation/ValidationControllerIntegrationTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/rest/validation/ValidationControllerIntegrationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/LdapServerResource.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/LdapServerResource.java index 341ffdd89..326bc5cd7 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/LdapServerResource.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/LdapServerResource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SecurityTestUtils.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SecurityTestUtils.java index d260c50d7..db4e3fb8b 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SecurityTestUtils.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SecurityTestUtils.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SingleNodeApplicationWithDefaultSecurityTest.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SingleNodeApplicationWithDefaultSecurityTest.java index 0bf9ba06f..321f3c9d3 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SingleNodeApplicationWithDefaultSecurityTest.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SingleNodeApplicationWithDefaultSecurityTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SingleNodeApplicationWithLdapSearchAndBindTest.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SingleNodeApplicationWithLdapSearchAndBindTest.java index 347a78c0f..0f4b5bf87 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SingleNodeApplicationWithLdapSearchAndBindTest.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SingleNodeApplicationWithLdapSearchAndBindTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SingleNodeApplicationWithLdapSimpleBindTest.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SingleNodeApplicationWithLdapSimpleBindTest.java index 9d21a6d63..e0ba3439f 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SingleNodeApplicationWithLdapSimpleBindTest.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SingleNodeApplicationWithLdapSimpleBindTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SingleNodeApplicationWithSslTest.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SingleNodeApplicationWithSslTest.java index 98818ad47..33a1ac8b4 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SingleNodeApplicationWithSslTest.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SingleNodeApplicationWithSslTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SingleNodeApplicationWithUserBasedSecurityTest.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SingleNodeApplicationWithUserBasedSecurityTest.java index e4f888f11..ffaa33f93 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SingleNodeApplicationWithUserBasedSecurityTest.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SingleNodeApplicationWithUserBasedSecurityTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SingleNodeApplicationWithUsersFileTest.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SingleNodeApplicationWithUsersFileTest.java index c706b5b4f..a17bf2708 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SingleNodeApplicationWithUsersFileTest.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SingleNodeApplicationWithUsersFileTest.java @@ -6,7 +6,7 @@ * * you may not use this file except in compliance with the License. * * You may obtain a copy of the License at * * - * * http://www.apache.org/licenses/LICENSE-2.0 + * * https://www.apache.org/licenses/LICENSE-2.0 * * * * Unless required by applicable law or agreed to in writing, software * * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SpringXdResource.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SpringXdResource.java index 8a9d57c02..6aceb3daf 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SpringXdResource.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/SpringXdResource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/support/UserCredentials.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/support/UserCredentials.java index b038af962..8109dcf3c 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/support/UserCredentials.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/security/support/UserCredentials.java @@ -6,7 +6,7 @@ * * you may not use this file except in compliance with the License. * * You may obtain a copy of the License at * * - * * http://www.apache.org/licenses/LICENSE-2.0 + * * https://www.apache.org/licenses/LICENSE-2.0 * * * * Unless required by applicable law or agreed to in writing, software * * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/server/ContainerServerApplicationTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/server/ContainerServerApplicationTests.java index e9823a2cd..1e9c94dfe 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/server/ContainerServerApplicationTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/server/ContainerServerApplicationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/server/TestApplicationBootstrap.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/server/TestApplicationBootstrap.java index 7d4f711ea..fb9af3345 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/server/TestApplicationBootstrap.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/server/TestApplicationBootstrap.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/server/admin/deployment/DefaultContainerMatcherTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/server/admin/deployment/DefaultContainerMatcherTests.java index 652d1e974..429a7e152 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/server/admin/deployment/DefaultContainerMatcherTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/server/admin/deployment/DefaultContainerMatcherTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/AbstractDistributedTransportSingleNodeStreamDeploymentIntegrationTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/AbstractDistributedTransportSingleNodeStreamDeploymentIntegrationTests.java index 0316e5cf9..9adc70cba 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/AbstractDistributedTransportSingleNodeStreamDeploymentIntegrationTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/AbstractDistributedTransportSingleNodeStreamDeploymentIntegrationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/AbstractSingleNodeStreamDeploymentIntegrationTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/AbstractSingleNodeStreamDeploymentIntegrationTests.java index 1942c3a5a..afcb1cdc8 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/AbstractSingleNodeStreamDeploymentIntegrationTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/AbstractSingleNodeStreamDeploymentIntegrationTests.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/ComposedModuleStreamTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/ComposedModuleStreamTests.java index 1919338fa..41f33ef4f 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/ComposedModuleStreamTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/ComposedModuleStreamTests.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/DeployerTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/DeployerTests.java index f3260daab..032c59321 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/DeployerTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/DeployerTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/DeploymentPropertiesParserTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/DeploymentPropertiesParserTests.java index 9929dda77..cb66e18f7 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/DeploymentPropertiesParserTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/DeploymentPropertiesParserTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/ExampleProcessingChainTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/ExampleProcessingChainTests.java index adf4b6de0..e08a8b77a 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/ExampleProcessingChainTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/ExampleProcessingChainTests.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/FileSourceModuleTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/FileSourceModuleTests.java index bc1041b7f..26e0994a7 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/FileSourceModuleTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/FileSourceModuleTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/KafkaSingleNodeStreamDeploymentIntegrationTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/KafkaSingleNodeStreamDeploymentIntegrationTests.java index 6d2d3f5b2..b73e0dedf 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/KafkaSingleNodeStreamDeploymentIntegrationTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/KafkaSingleNodeStreamDeploymentIntegrationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/LocalSingleNodeStreamDeploymentIntegrationTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/LocalSingleNodeStreamDeploymentIntegrationTests.java index 22eff693e..5c4989f2e 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/LocalSingleNodeStreamDeploymentIntegrationTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/LocalSingleNodeStreamDeploymentIntegrationTests.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/ModuleOptionsDefaultsOrderingTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/ModuleOptionsDefaultsOrderingTests.java index 5711144c5..c32b28ad5 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/ModuleOptionsDefaultsOrderingTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/ModuleOptionsDefaultsOrderingTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/RabbitSingleNodeStreamDeploymentIntegrationTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/RabbitSingleNodeStreamDeploymentIntegrationTests.java index 0b3c83a42..fe6aacd27 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/RabbitSingleNodeStreamDeploymentIntegrationTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/RabbitSingleNodeStreamDeploymentIntegrationTests.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/RedisSingleNodeStreamDeploymentIntegrationTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/RedisSingleNodeStreamDeploymentIntegrationTests.java index 918816075..64a9ad53a 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/RedisSingleNodeStreamDeploymentIntegrationTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/RedisSingleNodeStreamDeploymentIntegrationTests.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/StreamTestSupport.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/StreamTestSupport.java index 3bf0e2208..f75dbd78d 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/StreamTestSupport.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/StreamTestSupport.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/TypeConvertingStreamTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/TypeConvertingStreamTests.java index 087a35a0e..ce4ea0268 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/TypeConvertingStreamTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/TypeConvertingStreamTests.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/XDStreamParserTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/XDStreamParserTests.java index a70496721..fee53d127 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/XDStreamParserTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/XDStreamParserTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/completionnoscan/CompletionProviderTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/completionnoscan/CompletionProviderTests.java index 24591daad..66606e562 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/completionnoscan/CompletionProviderTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/completionnoscan/CompletionProviderTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/dsl/StreamConfigParserTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/dsl/StreamConfigParserTests.java index b1f3797ee..f8d47110d 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/dsl/StreamConfigParserTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/dsl/StreamConfigParserTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/dsl/TokenizerTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/dsl/TokenizerTests.java index 5097be246..903c8c96b 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/dsl/TokenizerTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/dsl/TokenizerTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/zookeeper/ZooKeeperStreamDefinitionRepositoryTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/zookeeper/ZooKeeperStreamDefinitionRepositoryTests.java index 13f61f176..96e338fe5 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/zookeeper/ZooKeeperStreamDefinitionRepositoryTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/stream/zookeeper/ZooKeeperStreamDefinitionRepositoryTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/util/PagingUtilityTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/util/PagingUtilityTests.java index ee7359c39..4c5eaa71a 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/util/PagingUtilityTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/dirt/util/PagingUtilityTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/extensions/ExtensionsTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/extensions/ExtensionsTests.java index da9d80094..41ab19896 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/extensions/ExtensionsTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/extensions/ExtensionsTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/extensions/PropertiesDecryptorTests.java b/spring-xd-dirt/src/test/java/org/springframework/xd/extensions/PropertiesDecryptorTests.java index feb0f62de..3f32b9d21 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/extensions/PropertiesDecryptorTests.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/extensions/PropertiesDecryptorTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/extensions/test/Bar.java b/spring-xd-dirt/src/test/java/org/springframework/xd/extensions/test/Bar.java index 06b3d3fa6..b9c26134a 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/extensions/test/Bar.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/extensions/test/Bar.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/extensions/test/Foo.java b/spring-xd-dirt/src/test/java/org/springframework/xd/extensions/test/Foo.java index b9d169d05..c2a7dc0ce 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/extensions/test/Foo.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/extensions/test/Foo.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/extensions/test/MyXDBeans.java b/spring-xd-dirt/src/test/java/org/springframework/xd/extensions/test/MyXDBeans.java index 487f895a0..0ccc1f1a0 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/extensions/test/MyXDBeans.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/extensions/test/MyXDBeans.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/org/springframework/xd/extensions/test/StubPojoToStringConverter.java b/spring-xd-dirt/src/test/java/org/springframework/xd/extensions/test/StubPojoToStringConverter.java index e758ba721..bf82d6c9b 100644 --- a/spring-xd-dirt/src/test/java/org/springframework/xd/extensions/test/StubPojoToStringConverter.java +++ b/spring-xd-dirt/src/test/java/org/springframework/xd/extensions/test/StubPojoToStringConverter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/spring/xd/bus/ext/CustomKryoRegistrarConfig.java b/spring-xd-dirt/src/test/java/spring/xd/bus/ext/CustomKryoRegistrarConfig.java index c95d45aca..fdebfdda1 100644 --- a/spring-xd-dirt/src/test/java/spring/xd/bus/ext/CustomKryoRegistrarConfig.java +++ b/spring-xd-dirt/src/test/java/spring/xd/bus/ext/CustomKryoRegistrarConfig.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/java/spring/xd/ext/encryption/MyDecryptor.java b/spring-xd-dirt/src/test/java/spring/xd/ext/encryption/MyDecryptor.java index b51362ccd..2b16ca692 100644 --- a/spring-xd-dirt/src/test/java/spring/xd/ext/encryption/MyDecryptor.java +++ b/spring-xd-dirt/src/test/java/spring/xd/ext/encryption/MyDecryptor.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-dirt/src/test/resources/logback.groovy b/spring-xd-dirt/src/test/resources/logback.groovy index 0ac578d3c..c74021b61 100644 --- a/spring-xd-dirt/src/test/resources/logback.groovy +++ b/spring-xd-dirt/src/test/resources/logback.groovy @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-distributed-test/src/main/java/org/springframework/xd/distributed/util/DefaultDistributedTestSupport.java b/spring-xd-distributed-test/src/main/java/org/springframework/xd/distributed/util/DefaultDistributedTestSupport.java index f863a69c2..ca1d1cf86 100644 --- a/spring-xd-distributed-test/src/main/java/org/springframework/xd/distributed/util/DefaultDistributedTestSupport.java +++ b/spring-xd-distributed-test/src/main/java/org/springframework/xd/distributed/util/DefaultDistributedTestSupport.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-distributed-test/src/main/java/org/springframework/xd/distributed/util/DistributedTestSupport.java b/spring-xd-distributed-test/src/main/java/org/springframework/xd/distributed/util/DistributedTestSupport.java index 1fcf972b2..fb2ba79c3 100644 --- a/spring-xd-distributed-test/src/main/java/org/springframework/xd/distributed/util/DistributedTestSupport.java +++ b/spring-xd-distributed-test/src/main/java/org/springframework/xd/distributed/util/DistributedTestSupport.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-distributed-test/src/main/java/org/springframework/xd/distributed/util/ServerProcessUtils.java b/spring-xd-distributed-test/src/main/java/org/springframework/xd/distributed/util/ServerProcessUtils.java index 4f8465f33..9ea8f109b 100644 --- a/spring-xd-distributed-test/src/main/java/org/springframework/xd/distributed/util/ServerProcessUtils.java +++ b/spring-xd-distributed-test/src/main/java/org/springframework/xd/distributed/util/ServerProcessUtils.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-distributed-test/src/test/java/org/springframework/xd/distributed/test/AbstractDistributedTests.java b/spring-xd-distributed-test/src/test/java/org/springframework/xd/distributed/test/AbstractDistributedTests.java index eccd75d61..612d5ba3e 100644 --- a/spring-xd-distributed-test/src/test/java/org/springframework/xd/distributed/test/AbstractDistributedTests.java +++ b/spring-xd-distributed-test/src/test/java/org/springframework/xd/distributed/test/AbstractDistributedTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-distributed-test/src/test/java/org/springframework/xd/distributed/test/ContainerRedeploymentTests.java b/spring-xd-distributed-test/src/test/java/org/springframework/xd/distributed/test/ContainerRedeploymentTests.java index 6ebf8700c..b9a75adc9 100644 --- a/spring-xd-distributed-test/src/test/java/org/springframework/xd/distributed/test/ContainerRedeploymentTests.java +++ b/spring-xd-distributed-test/src/test/java/org/springframework/xd/distributed/test/ContainerRedeploymentTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-distributed-test/src/test/java/org/springframework/xd/distributed/test/DistributedTestSuite.java b/spring-xd-distributed-test/src/test/java/org/springframework/xd/distributed/test/DistributedTestSuite.java index 6eb69dba3..50777e284 100644 --- a/spring-xd-distributed-test/src/test/java/org/springframework/xd/distributed/test/DistributedTestSuite.java +++ b/spring-xd-distributed-test/src/test/java/org/springframework/xd/distributed/test/DistributedTestSuite.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-distributed-test/src/test/java/org/springframework/xd/distributed/test/JobStateTests.java b/spring-xd-distributed-test/src/test/java/org/springframework/xd/distributed/test/JobStateTests.java index baf317a83..454662bea 100644 --- a/spring-xd-distributed-test/src/test/java/org/springframework/xd/distributed/test/JobStateTests.java +++ b/spring-xd-distributed-test/src/test/java/org/springframework/xd/distributed/test/JobStateTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-distributed-test/src/test/java/org/springframework/xd/distributed/test/StreamDeploymentTests.java b/spring-xd-distributed-test/src/test/java/org/springframework/xd/distributed/test/StreamDeploymentTests.java index 8759c18ae..c15d434ff 100644 --- a/spring-xd-distributed-test/src/test/java/org/springframework/xd/distributed/test/StreamDeploymentTests.java +++ b/spring-xd-distributed-test/src/test/java/org/springframework/xd/distributed/test/StreamDeploymentTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-distributed-test/src/test/java/org/springframework/xd/distributed/test/StreamPartitionTests.java b/spring-xd-distributed-test/src/test/java/org/springframework/xd/distributed/test/StreamPartitionTests.java index 7827c905c..c3e0c8d2a 100644 --- a/spring-xd-distributed-test/src/test/java/org/springframework/xd/distributed/test/StreamPartitionTests.java +++ b/spring-xd-distributed-test/src/test/java/org/springframework/xd/distributed/test/StreamPartitionTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-distributed-test/src/test/java/org/springframework/xd/distributed/test/StreamStateTests.java b/spring-xd-distributed-test/src/test/java/org/springframework/xd/distributed/test/StreamStateTests.java index 4c90b125e..b4b10e36c 100644 --- a/spring-xd-distributed-test/src/test/java/org/springframework/xd/distributed/test/StreamStateTests.java +++ b/spring-xd-distributed-test/src/test/java/org/springframework/xd/distributed/test/StreamStateTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-gemfire-server/src/main/java/org/springframework/xd/gemfire/server/CacheServer.java b/spring-xd-gemfire-server/src/main/java/org/springframework/xd/gemfire/server/CacheServer.java index 11a6a3424..9bd78344a 100644 --- a/spring-xd-gemfire-server/src/main/java/org/springframework/xd/gemfire/server/CacheServer.java +++ b/spring-xd-gemfire-server/src/main/java/org/springframework/xd/gemfire/server/CacheServer.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-gemfire-server/src/main/java/org/springframework/xd/gemfire/server/LoggingCacheListener.java b/spring-xd-gemfire-server/src/main/java/org/springframework/xd/gemfire/server/LoggingCacheListener.java index 397de472b..88efe1e71 100644 --- a/spring-xd-gemfire-server/src/main/java/org/springframework/xd/gemfire/server/LoggingCacheListener.java +++ b/spring-xd-gemfire-server/src/main/java/org/springframework/xd/gemfire/server/LoggingCacheListener.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-gradle-plugins/spring-xd-module-plugin/src/main/groovy/org/springframework/xd/gradle/plugin/ModulePlugin.groovy b/spring-xd-gradle-plugins/spring-xd-module-plugin/src/main/groovy/org/springframework/xd/gradle/plugin/ModulePlugin.groovy index ac27c2a3b..57d71f43f 100644 --- a/spring-xd-gradle-plugins/spring-xd-module-plugin/src/main/groovy/org/springframework/xd/gradle/plugin/ModulePlugin.groovy +++ b/spring-xd-gradle-plugins/spring-xd-module-plugin/src/main/groovy/org/springframework/xd/gradle/plugin/ModulePlugin.groovy @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/batch/item/hadoop/AbstractHdfsItemWriter.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/batch/item/hadoop/AbstractHdfsItemWriter.java index d9d7fa8ed..a52324d87 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/batch/item/hadoop/AbstractHdfsItemWriter.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/batch/item/hadoop/AbstractHdfsItemWriter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/batch/item/hadoop/HdfsTextItemWriter.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/batch/item/hadoop/HdfsTextItemWriter.java index fdd9b962e..20942cfb1 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/batch/item/hadoop/HdfsTextItemWriter.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/batch/item/hadoop/HdfsTextItemWriter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/batch/item/hadoop/SimpleAbstractHdfsItemWriter.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/batch/item/hadoop/SimpleAbstractHdfsItemWriter.java index eb702b4c9..9da21bc6e 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/batch/item/hadoop/SimpleAbstractHdfsItemWriter.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/batch/item/hadoop/SimpleAbstractHdfsItemWriter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/batch/item/hadoop/SimpleHdfsTextItemWriter.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/batch/item/hadoop/SimpleHdfsTextItemWriter.java index 8bd369a21..a229c8688 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/batch/item/hadoop/SimpleHdfsTextItemWriter.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/batch/item/hadoop/SimpleHdfsTextItemWriter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/AbstractHdfsWriter.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/AbstractHdfsWriter.java index 55cb9e300..4ec489f96 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/AbstractHdfsWriter.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/AbstractHdfsWriter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/DatasetDefinitionFactoryBean.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/DatasetDefinitionFactoryBean.java index 7057c9e70..7bec7e63b 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/DatasetDefinitionFactoryBean.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/DatasetDefinitionFactoryBean.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/DatasetWriter.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/DatasetWriter.java index 6df0d8484..51f1720af 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/DatasetWriter.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/DatasetWriter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/DatasetWriterFactory.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/DatasetWriterFactory.java index b00b23528..73c21ef76 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/DatasetWriterFactory.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/DatasetWriterFactory.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/HdfsTextFileWriter.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/HdfsTextFileWriter.java index a5b6264aa..06ddda6b4 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/HdfsTextFileWriter.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/HdfsTextFileWriter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/HdfsTextFileWriterFactory.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/HdfsTextFileWriterFactory.java index a1ee3664b..1d7636268 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/HdfsTextFileWriterFactory.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/HdfsTextFileWriterFactory.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/HdfsWriter.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/HdfsWriter.java index 9bc71a355..d2235d0cc 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/HdfsWriter.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/HdfsWriter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/HdfsWriterFactory.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/HdfsWriterFactory.java index c22b30e84..daf57d862 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/HdfsWriterFactory.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/hadoop/fs/HdfsWriterFactory.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/IntegrationHadoopSystemConstants.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/IntegrationHadoopSystemConstants.java index dcdade357..911147352 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/IntegrationHadoopSystemConstants.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/IntegrationHadoopSystemConstants.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/DatasetOutboundChannelAdapterParser.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/DatasetOutboundChannelAdapterParser.java index 235bc91d1..1be7cd9b1 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/DatasetOutboundChannelAdapterParser.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/DatasetOutboundChannelAdapterParser.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/DatasetWritingMessageHandlerFactoryBean.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/DatasetWritingMessageHandlerFactoryBean.java index 32434a4da..5e00f6df6 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/DatasetWritingMessageHandlerFactoryBean.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/DatasetWritingMessageHandlerFactoryBean.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/HadoopNamespaceHandler.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/HadoopNamespaceHandler.java index 412f94049..6d4c18314 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/HadoopNamespaceHandler.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/HadoopNamespaceHandler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/HdfsOutboundChannelAdapterParser.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/HdfsOutboundChannelAdapterParser.java index f576551a2..e83e4f8fa 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/HdfsOutboundChannelAdapterParser.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/HdfsOutboundChannelAdapterParser.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/HdfsStoreMessageHandlerBeanDefinitionBuilder.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/HdfsStoreMessageHandlerBeanDefinitionBuilder.java index 73de5aa6c..271be3495 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/HdfsStoreMessageHandlerBeanDefinitionBuilder.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/HdfsStoreMessageHandlerBeanDefinitionBuilder.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/HdfsStoreMessageHandlerFactoryBean.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/HdfsStoreMessageHandlerFactoryBean.java index 843c884e2..b5c809b46 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/HdfsStoreMessageHandlerFactoryBean.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/HdfsStoreMessageHandlerFactoryBean.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/HdfsWritingMessageHandlerFactoryBean.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/HdfsWritingMessageHandlerFactoryBean.java index 6cd3bca2d..a297f6b8d 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/HdfsWritingMessageHandlerFactoryBean.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/HdfsWritingMessageHandlerFactoryBean.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/IntegrationHadoopNamespaceUtils.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/IntegrationHadoopNamespaceUtils.java index 5321237e7..65a01c659 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/IntegrationHadoopNamespaceUtils.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/IntegrationHadoopNamespaceUtils.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/NamingStrategyParser.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/NamingStrategyParser.java index 76cab6a04..f6974236d 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/NamingStrategyParser.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/NamingStrategyParser.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/RolloverStrategyParser.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/RolloverStrategyParser.java index cee0e6078..0339c457e 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/RolloverStrategyParser.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/RolloverStrategyParser.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/StoreWriterFactoryBean.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/StoreWriterFactoryBean.java index 36a0820a1..601cc6db1 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/StoreWriterFactoryBean.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/StoreWriterFactoryBean.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/StoreWriterParser.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/StoreWriterParser.java index 640481378..b30b0016e 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/StoreWriterParser.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/config/StoreWriterParser.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/expression/MessageExpressionMethods.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/expression/MessageExpressionMethods.java index 6eec1e384..dd3e95d1f 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/expression/MessageExpressionMethods.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/expression/MessageExpressionMethods.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/expression/MessagePartitionKeyMethodResolver.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/expression/MessagePartitionKeyMethodResolver.java index 0ec617314..60bd95b98 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/expression/MessagePartitionKeyMethodResolver.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/expression/MessagePartitionKeyMethodResolver.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/expression/MessagePartitionKeyPropertyAccessor.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/expression/MessagePartitionKeyPropertyAccessor.java index f9670d5c5..c2c09dee9 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/expression/MessagePartitionKeyPropertyAccessor.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/expression/MessagePartitionKeyPropertyAccessor.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/outbound/HdfsDataStoreMessageHandler.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/outbound/HdfsDataStoreMessageHandler.java index 71cad7951..9aa155dcb 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/outbound/HdfsDataStoreMessageHandler.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/outbound/HdfsDataStoreMessageHandler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/outbound/HdfsPartitionDataStoreMessageHandler.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/outbound/HdfsPartitionDataStoreMessageHandler.java index 40d9e2829..9a64ada53 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/outbound/HdfsPartitionDataStoreMessageHandler.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/outbound/HdfsPartitionDataStoreMessageHandler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/outbound/HdfsStoreMessageHandler.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/outbound/HdfsStoreMessageHandler.java index 8f61606ed..c4ec59d8f 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/outbound/HdfsStoreMessageHandler.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/outbound/HdfsStoreMessageHandler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/outbound/HdfsWritingMessageHandler.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/outbound/HdfsWritingMessageHandler.java index a3e714702..0b12e2d2a 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/outbound/HdfsWritingMessageHandler.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/outbound/HdfsWritingMessageHandler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/partition/MessagePartitionStrategy.java b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/partition/MessagePartitionStrategy.java index 7ee01a909..099315f26 100644 --- a/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/partition/MessagePartitionStrategy.java +++ b/spring-xd-hadoop/src/main/java/org/springframework/xd/integration/hadoop/partition/MessagePartitionStrategy.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/test/java/org/springframework/xd/hadoop/fs/StubDatasetOperations.java b/spring-xd-hadoop/src/test/java/org/springframework/xd/hadoop/fs/StubDatasetOperations.java index a68a8ce8d..124ac8f9f 100644 --- a/spring-xd-hadoop/src/test/java/org/springframework/xd/hadoop/fs/StubDatasetOperations.java +++ b/spring-xd-hadoop/src/test/java/org/springframework/xd/hadoop/fs/StubDatasetOperations.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/test/java/org/springframework/xd/hadoop/fs/StubFileSystem.java b/spring-xd-hadoop/src/test/java/org/springframework/xd/hadoop/fs/StubFileSystem.java index bfb6975ed..805d537c5 100644 --- a/spring-xd-hadoop/src/test/java/org/springframework/xd/hadoop/fs/StubFileSystem.java +++ b/spring-xd-hadoop/src/test/java/org/springframework/xd/hadoop/fs/StubFileSystem.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/test/java/org/springframework/xd/integration/hadoop/config/DatasetOutboundChannelAdapterIntegrationTests.java b/spring-xd-hadoop/src/test/java/org/springframework/xd/integration/hadoop/config/DatasetOutboundChannelAdapterIntegrationTests.java index 20f96ef99..fc320fc2c 100644 --- a/spring-xd-hadoop/src/test/java/org/springframework/xd/integration/hadoop/config/DatasetOutboundChannelAdapterIntegrationTests.java +++ b/spring-xd-hadoop/src/test/java/org/springframework/xd/integration/hadoop/config/DatasetOutboundChannelAdapterIntegrationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/test/java/org/springframework/xd/integration/hadoop/config/DatasetOutboundChannelAdapterParserTests.java b/spring-xd-hadoop/src/test/java/org/springframework/xd/integration/hadoop/config/DatasetOutboundChannelAdapterParserTests.java index 4784ba926..cdbdc6cc6 100644 --- a/spring-xd-hadoop/src/test/java/org/springframework/xd/integration/hadoop/config/DatasetOutboundChannelAdapterParserTests.java +++ b/spring-xd-hadoop/src/test/java/org/springframework/xd/integration/hadoop/config/DatasetOutboundChannelAdapterParserTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/test/java/org/springframework/xd/integration/hadoop/config/DatasetOutboundChannelAdapterPartitionedIntegrationTests.java b/spring-xd-hadoop/src/test/java/org/springframework/xd/integration/hadoop/config/DatasetOutboundChannelAdapterPartitionedIntegrationTests.java index d98eb35cf..d3f2463f1 100644 --- a/spring-xd-hadoop/src/test/java/org/springframework/xd/integration/hadoop/config/DatasetOutboundChannelAdapterPartitionedIntegrationTests.java +++ b/spring-xd-hadoop/src/test/java/org/springframework/xd/integration/hadoop/config/DatasetOutboundChannelAdapterPartitionedIntegrationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/test/java/org/springframework/xd/integration/hadoop/config/HdfsOutboundChannelAdapterIntegrationTests.java b/spring-xd-hadoop/src/test/java/org/springframework/xd/integration/hadoop/config/HdfsOutboundChannelAdapterIntegrationTests.java index 9931b834a..9084d4757 100644 --- a/spring-xd-hadoop/src/test/java/org/springframework/xd/integration/hadoop/config/HdfsOutboundChannelAdapterIntegrationTests.java +++ b/spring-xd-hadoop/src/test/java/org/springframework/xd/integration/hadoop/config/HdfsOutboundChannelAdapterIntegrationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/test/java/org/springframework/xd/integration/hadoop/config/HdfsOutboundChannelAdapterParserTests.java b/spring-xd-hadoop/src/test/java/org/springframework/xd/integration/hadoop/config/HdfsOutboundChannelAdapterParserTests.java index f0c529dd1..ca12fe3ef 100644 --- a/spring-xd-hadoop/src/test/java/org/springframework/xd/integration/hadoop/config/HdfsOutboundChannelAdapterParserTests.java +++ b/spring-xd-hadoop/src/test/java/org/springframework/xd/integration/hadoop/config/HdfsOutboundChannelAdapterParserTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/test/java/org/springframework/xd/integration/hadoop/config/NamingStrategyParserTests.java b/spring-xd-hadoop/src/test/java/org/springframework/xd/integration/hadoop/config/NamingStrategyParserTests.java index c101f9b72..4aabaef34 100644 --- a/spring-xd-hadoop/src/test/java/org/springframework/xd/integration/hadoop/config/NamingStrategyParserTests.java +++ b/spring-xd-hadoop/src/test/java/org/springframework/xd/integration/hadoop/config/NamingStrategyParserTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-hadoop/src/test/java/org/springframework/xd/test/TestPojo.java b/spring-xd-hadoop/src/test/java/org/springframework/xd/test/TestPojo.java index 8f08f2106..a5562aff0 100644 --- a/spring-xd-hadoop/src/test/java/org/springframework/xd/test/TestPojo.java +++ b/spring-xd-hadoop/src/test/java/org/springframework/xd/test/TestPojo.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/acceptance-test-sparkapp/src/main/java/spark/SparkPi.java b/spring-xd-integration-test/acceptance-test-sparkapp/src/main/java/spark/SparkPi.java index 895e87994..52062607c 100644 --- a/spring-xd-integration-test/acceptance-test-sparkapp/src/main/java/spark/SparkPi.java +++ b/spring-xd-integration-test/acceptance-test-sparkapp/src/main/java/spark/SparkPi.java @@ -6,7 +6,7 @@ * * you may not use this file except in compliance with the License. * * You may obtain a copy of the License at * * - * * http://www.apache.org/licenses/LICENSE-2.0 + * * https://www.apache.org/licenses/LICENSE-2.0 * * * * Unless required by applicable law or agreed to in writing, software * * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/fixtures/ContainerResolver.java b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/fixtures/ContainerResolver.java index 770bde1b9..f3f42d414 100644 --- a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/fixtures/ContainerResolver.java +++ b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/fixtures/ContainerResolver.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/fixtures/Jobs.java b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/fixtures/Jobs.java index 9b91740aa..1ead91806 100644 --- a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/fixtures/Jobs.java +++ b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/fixtures/Jobs.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/fixtures/ModuleFixture.java b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/fixtures/ModuleFixture.java index fec642f56..b22aa8d78 100644 --- a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/fixtures/ModuleFixture.java +++ b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/fixtures/ModuleFixture.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/fixtures/ModuleType.java b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/fixtures/ModuleType.java index 94051fb51..d70855dd5 100644 --- a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/fixtures/ModuleType.java +++ b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/fixtures/ModuleType.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/fixtures/Processors.java b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/fixtures/Processors.java index 84525fb34..6e059af04 100644 --- a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/fixtures/Processors.java +++ b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/fixtures/Processors.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/fixtures/Sinks.java b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/fixtures/Sinks.java index 48e7cd50e..9e62e5324 100644 --- a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/fixtures/Sinks.java +++ b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/fixtures/Sinks.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/fixtures/Sources.java b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/fixtures/Sources.java index 15602dc81..ddc85be63 100644 --- a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/fixtures/Sources.java +++ b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/fixtures/Sources.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/ConfigUtil.java b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/ConfigUtil.java index a1043c641..171703f04 100644 --- a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/ConfigUtil.java +++ b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/ConfigUtil.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/HadoopUtils.java b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/HadoopUtils.java index 8358f3022..42fba0e88 100644 --- a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/HadoopUtils.java +++ b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/HadoopUtils.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/InvalidResultException.java b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/InvalidResultException.java index cd6912488..b5ef75ac1 100644 --- a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/InvalidResultException.java +++ b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/InvalidResultException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/StreamUtils.java b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/StreamUtils.java index 1f472b83e..1669284da 100644 --- a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/StreamUtils.java +++ b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/StreamUtils.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/XdEc2Validation.java b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/XdEc2Validation.java index fc53d9737..7eec12274 100644 --- a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/XdEc2Validation.java +++ b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/XdEc2Validation.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/XdEnvironment.java b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/XdEnvironment.java index 82dad7da6..30746a087 100644 --- a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/XdEnvironment.java +++ b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/XdEnvironment.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/jmxresult/JMXChannelResult.java b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/jmxresult/JMXChannelResult.java index 38ac86bfa..1924036b5 100644 --- a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/jmxresult/JMXChannelResult.java +++ b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/jmxresult/JMXChannelResult.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/jmxresult/JMXRequest.java b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/jmxresult/JMXRequest.java index 4740e6682..202504335 100644 --- a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/jmxresult/JMXRequest.java +++ b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/jmxresult/JMXRequest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/jmxresult/JMXResult.java b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/jmxresult/JMXResult.java index d1fff41db..bc62ed8e1 100644 --- a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/jmxresult/JMXResult.java +++ b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/jmxresult/JMXResult.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/jmxresult/JMXValue.java b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/jmxresult/JMXValue.java index ad1512878..bd47267b6 100644 --- a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/jmxresult/JMXValue.java +++ b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/jmxresult/JMXValue.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/jmxresult/Module.java b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/jmxresult/Module.java index b0a40c99a..3b4526c8c 100644 --- a/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/jmxresult/Module.java +++ b/spring-xd-integration-test/src/main/java/org/springframework/xd/integration/util/jmxresult/Module.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/AbstractIntegrationTest.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/AbstractIntegrationTest.java index 0e8eda3be..05798cd06 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/AbstractIntegrationTest.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/AbstractIntegrationTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/AbstractJobTest.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/AbstractJobTest.java index 2e6afcd1a..2a62a6cb9 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/AbstractJobTest.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/AbstractJobTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/BasicJobTest.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/BasicJobTest.java index ee643b1d5..7c43bfc26 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/BasicJobTest.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/BasicJobTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/CountTests.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/CountTests.java index 4d304c0ba..64416c72c 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/CountTests.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/CountTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/FileJdbcTest.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/FileJdbcTest.java index f319c3cb3..e4a3929c3 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/FileJdbcTest.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/FileJdbcTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/FilePollHdfsTest.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/FilePollHdfsTest.java index 6cd1ec2db..e599acb3f 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/FilePollHdfsTest.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/FilePollHdfsTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/FileSourceTest.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/FileSourceTest.java index e718a57b6..e143d7e58 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/FileSourceTest.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/FileSourceTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/FtpHdfsTest.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/FtpHdfsTest.java index 0c376503f..5e082f1ab 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/FtpHdfsTest.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/FtpHdfsTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/GemfireTests.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/GemfireTests.java index b11f03351..e505141c1 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/GemfireTests.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/GemfireTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/HdfsJdbcTest.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/HdfsJdbcTest.java index 6a4a7ced5..5c5c9eb78 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/HdfsJdbcTest.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/HdfsJdbcTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/HdfsMongoDbTest.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/HdfsMongoDbTest.java index 85de62dda..f5a243b38 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/HdfsMongoDbTest.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/HdfsMongoDbTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/HdfsTest.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/HdfsTest.java index 58ab43dd6..24016a308 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/HdfsTest.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/HdfsTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/HttpTest.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/HttpTest.java index bb1ee8666..02c4f7fa1 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/HttpTest.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/HttpTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/IntegrationTestConfig.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/IntegrationTestConfig.java index 11da139b0..aa7c3dcfe 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/IntegrationTestConfig.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/IntegrationTestConfig.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/JdbcHdfsTest.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/JdbcHdfsTest.java index 3c80d183a..31a21fe6e 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/JdbcHdfsTest.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/JdbcHdfsTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/JdbcTest.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/JdbcTest.java index 122e7695c..9e688301c 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/JdbcTest.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/JdbcTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/JmsTest.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/JmsTest.java index 6c25be873..fb1635322 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/JmsTest.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/JmsTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/JobCommandTest.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/JobCommandTest.java index 0f2a1e127..f15493f91 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/JobCommandTest.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/JobCommandTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/KafkaTests.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/KafkaTests.java index e6f353516..a709ab4f6 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/KafkaTests.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/KafkaTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/MqttTest.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/MqttTest.java index 2625ff4c6..0207e8876 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/MqttTest.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/MqttTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/ProcessorTest.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/ProcessorTest.java index dea8ed596..8283c4bf6 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/ProcessorTest.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/ProcessorTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/RabbitTest.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/RabbitTest.java index 9bd869489..4fdb8fdd4 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/RabbitTest.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/RabbitTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/SimpleJobTest.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/SimpleJobTest.java index 2bb9b51dd..576dd6e9f 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/SimpleJobTest.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/SimpleJobTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/SparkAppTests.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/SparkAppTests.java index 62f141dfe..6023cae40 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/SparkAppTests.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/SparkAppTests.java @@ -6,7 +6,7 @@ * * you may not use this file except in compliance with the License. * * You may obtain a copy of the License at * * - * * http://www.apache.org/licenses/LICENSE-2.0 + * * https://www.apache.org/licenses/LICENSE-2.0 * * * * Unless required by applicable law or agreed to in writing, software * * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/SyslogTest.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/SyslogTest.java index d10ea58b2..3bd176513 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/SyslogTest.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/SyslogTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/TapTest.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/TapTest.java index 8cae5f592..543021433 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/TapTest.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/TapTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/TcpClientTests.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/TcpClientTests.java index 32df101c8..774716234 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/TcpClientTests.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/TcpClientTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/TcpTest.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/TcpTest.java index fa45c1dd7..00be55557 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/TcpTest.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/TcpTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/TickTockTest.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/TickTockTest.java index 79613edcc..572aa8661 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/TickTockTest.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/TickTockTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/TwitterSearchTest.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/TwitterSearchTest.java index 703d4ad4a..0f65c3bf6 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/TwitterSearchTest.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/TwitterSearchTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/TwitterStreamTest.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/TwitterStreamTest.java index 264852d88..ccf1b3db3 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/TwitterStreamTest.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/TwitterStreamTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/util/JMXTest.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/util/JMXTest.java index 8a146abaf..e84f9a8a7 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/util/JMXTest.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/util/JMXTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/util/package-info.java b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/util/package-info.java index cb7b9ef3c..3e6a5f5f1 100644 --- a/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/util/package-info.java +++ b/spring-xd-integration-test/src/test/java/org/springframework/xd/integration/test/util/package-info.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-messagebus-kafka/src/main/java/org/springframework/xd/dirt/integration/kafka/IntegerEncoderDecoder.java b/spring-xd-messagebus-kafka/src/main/java/org/springframework/xd/dirt/integration/kafka/IntegerEncoderDecoder.java index 2b7b6501f..d6a92f293 100644 --- a/spring-xd-messagebus-kafka/src/main/java/org/springframework/xd/dirt/integration/kafka/IntegerEncoderDecoder.java +++ b/spring-xd-messagebus-kafka/src/main/java/org/springframework/xd/dirt/integration/kafka/IntegerEncoderDecoder.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-messagebus-kafka/src/main/java/org/springframework/xd/dirt/integration/kafka/KafkaMessageBus.java b/spring-xd-messagebus-kafka/src/main/java/org/springframework/xd/dirt/integration/kafka/KafkaMessageBus.java index 9459f9352..d7569a776 100644 --- a/spring-xd-messagebus-kafka/src/main/java/org/springframework/xd/dirt/integration/kafka/KafkaMessageBus.java +++ b/spring-xd-messagebus-kafka/src/main/java/org/springframework/xd/dirt/integration/kafka/KafkaMessageBus.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-messagebus-local/src/main/java/org/springframework/xd/dirt/integration/bus/local/LocalMessageBus.java b/spring-xd-messagebus-local/src/main/java/org/springframework/xd/dirt/integration/bus/local/LocalMessageBus.java index fb45b4cd3..d67659b0a 100644 --- a/spring-xd-messagebus-local/src/main/java/org/springframework/xd/dirt/integration/bus/local/LocalMessageBus.java +++ b/spring-xd-messagebus-local/src/main/java/org/springframework/xd/dirt/integration/bus/local/LocalMessageBus.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-messagebus-rabbit/src/main/java/org/springframework/xd/dirt/integration/rabbit/ConnectionFactorySettings.java b/spring-xd-messagebus-rabbit/src/main/java/org/springframework/xd/dirt/integration/rabbit/ConnectionFactorySettings.java index 94041d29a..eb319250c 100644 --- a/spring-xd-messagebus-rabbit/src/main/java/org/springframework/xd/dirt/integration/rabbit/ConnectionFactorySettings.java +++ b/spring-xd-messagebus-rabbit/src/main/java/org/springframework/xd/dirt/integration/rabbit/ConnectionFactorySettings.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-messagebus-rabbit/src/main/java/org/springframework/xd/dirt/integration/rabbit/LocalizedQueueConnectionFactory.java b/spring-xd-messagebus-rabbit/src/main/java/org/springframework/xd/dirt/integration/rabbit/LocalizedQueueConnectionFactory.java index e93c08190..240c66c3d 100644 --- a/spring-xd-messagebus-rabbit/src/main/java/org/springframework/xd/dirt/integration/rabbit/LocalizedQueueConnectionFactory.java +++ b/spring-xd-messagebus-rabbit/src/main/java/org/springframework/xd/dirt/integration/rabbit/LocalizedQueueConnectionFactory.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-messagebus-rabbit/src/main/java/org/springframework/xd/dirt/integration/rabbit/RabbitMessageBus.java b/spring-xd-messagebus-rabbit/src/main/java/org/springframework/xd/dirt/integration/rabbit/RabbitMessageBus.java index 110b970cb..349e1ead3 100644 --- a/spring-xd-messagebus-rabbit/src/main/java/org/springframework/xd/dirt/integration/rabbit/RabbitMessageBus.java +++ b/spring-xd-messagebus-rabbit/src/main/java/org/springframework/xd/dirt/integration/rabbit/RabbitMessageBus.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-messagebus-rabbit/src/test/java/org/springframework/xd/dirt/integration/rabbit/LocalizedQueueConnectionFactoryIntegrationTests.java b/spring-xd-messagebus-rabbit/src/test/java/org/springframework/xd/dirt/integration/rabbit/LocalizedQueueConnectionFactoryIntegrationTests.java index df0272f26..dbdfed1b6 100644 --- a/spring-xd-messagebus-rabbit/src/test/java/org/springframework/xd/dirt/integration/rabbit/LocalizedQueueConnectionFactoryIntegrationTests.java +++ b/spring-xd-messagebus-rabbit/src/test/java/org/springframework/xd/dirt/integration/rabbit/LocalizedQueueConnectionFactoryIntegrationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-messagebus-rabbit/src/test/java/org/springframework/xd/dirt/integration/rabbit/LocalizedQueueConnectionFactoryTests.java b/spring-xd-messagebus-rabbit/src/test/java/org/springframework/xd/dirt/integration/rabbit/LocalizedQueueConnectionFactoryTests.java index e068a3256..51c76723c 100644 --- a/spring-xd-messagebus-rabbit/src/test/java/org/springframework/xd/dirt/integration/rabbit/LocalizedQueueConnectionFactoryTests.java +++ b/spring-xd-messagebus-rabbit/src/test/java/org/springframework/xd/dirt/integration/rabbit/LocalizedQueueConnectionFactoryTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-messagebus-redis/src/main/java/org/springframework/xd/dirt/integration/redis/RedisMessageBus.java b/spring-xd-messagebus-redis/src/main/java/org/springframework/xd/dirt/integration/redis/RedisMessageBus.java index a8f925991..1667e8aaf 100644 --- a/spring-xd-messagebus-redis/src/main/java/org/springframework/xd/dirt/integration/redis/RedisMessageBus.java +++ b/spring-xd-messagebus-redis/src/main/java/org/springframework/xd/dirt/integration/redis/RedisMessageBus.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/AbstractBusPropertiesAccessor.java b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/AbstractBusPropertiesAccessor.java index f6cc88199..8cc171d3d 100644 --- a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/AbstractBusPropertiesAccessor.java +++ b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/AbstractBusPropertiesAccessor.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/Binding.java b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/Binding.java index 78cd86730..e78baf6ac 100644 --- a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/Binding.java +++ b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/Binding.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/BusProperties.java b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/BusProperties.java index 8c9881c34..185ed4467 100644 --- a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/BusProperties.java +++ b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/BusProperties.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/BusUtils.java b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/BusUtils.java index 0afe9670f..090d4ca10 100644 --- a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/BusUtils.java +++ b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/BusUtils.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/EmbeddedHeadersMessageConverter.java b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/EmbeddedHeadersMessageConverter.java index 3270a5a70..4326283f5 100644 --- a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/EmbeddedHeadersMessageConverter.java +++ b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/EmbeddedHeadersMessageConverter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/MessageBus.java b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/MessageBus.java index beb9c53b8..82b0ab0de 100644 --- a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/MessageBus.java +++ b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/MessageBus.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/MessageBusException.java b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/MessageBusException.java index 46e17d012..29f750ac5 100644 --- a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/MessageBusException.java +++ b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/MessageBusException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/MessageBusSupport.java b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/MessageBusSupport.java index 27c38ba0f..59ec6cf75 100644 --- a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/MessageBusSupport.java +++ b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/MessageBusSupport.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/MessageValues.java b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/MessageValues.java index 959f29691..3f1ce2c7a 100644 --- a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/MessageValues.java +++ b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/MessageValues.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/PartitionKeyExtractorStrategy.java b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/PartitionKeyExtractorStrategy.java index cecd3af14..3a85b68cb 100644 --- a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/PartitionKeyExtractorStrategy.java +++ b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/PartitionKeyExtractorStrategy.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/PartitionSelectorStrategy.java b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/PartitionSelectorStrategy.java index c4a0ea2ca..4c5848777 100644 --- a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/PartitionSelectorStrategy.java +++ b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/PartitionSelectorStrategy.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/RabbitAdminException.java b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/RabbitAdminException.java index eff882004..bbe71db02 100644 --- a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/RabbitAdminException.java +++ b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/RabbitAdminException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/RabbitManagementUtils.java b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/RabbitManagementUtils.java index 2bcd6f9e8..87c63fb06 100644 --- a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/RabbitManagementUtils.java +++ b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/RabbitManagementUtils.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/SerializationException.java b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/SerializationException.java index d29081f72..542fc701f 100644 --- a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/SerializationException.java +++ b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/SerializationException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/StringConvertingContentTypeResolver.java b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/StringConvertingContentTypeResolver.java index e68f7f5e8..9ff868f9c 100644 --- a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/StringConvertingContentTypeResolver.java +++ b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/StringConvertingContentTypeResolver.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/XdHeaders.java b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/XdHeaders.java index c26f392be..58d965313 100644 --- a/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/XdHeaders.java +++ b/spring-xd-messagebus-spi/src/main/java/org/springframework/xd/dirt/integration/bus/XdHeaders.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-messagebus-spi/src/test/java/org/springframework/xd/dirt/integration/bus/MessageConverterTests.java b/spring-xd-messagebus-spi/src/test/java/org/springframework/xd/dirt/integration/bus/MessageConverterTests.java index f49651e0f..b38fa2204 100644 --- a/spring-xd-messagebus-spi/src/test/java/org/springframework/xd/dirt/integration/bus/MessageConverterTests.java +++ b/spring-xd-messagebus-spi/src/test/java/org/springframework/xd/dirt/integration/bus/MessageConverterTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/BatchJobCommitIntervalOptionMixin.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/BatchJobCommitIntervalOptionMixin.java index 644ab8d8e..768c23570 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/BatchJobCommitIntervalOptionMixin.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/BatchJobCommitIntervalOptionMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/BatchJobDeleteFilesOptionMixin.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/BatchJobDeleteFilesOptionMixin.java index 3d1b81a91..b47e75cf4 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/BatchJobDeleteFilesOptionMixin.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/BatchJobDeleteFilesOptionMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/BatchJobFieldDelimiterOptionMixin.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/BatchJobFieldDelimiterOptionMixin.java index b9d3be555..22002e225 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/BatchJobFieldDelimiterOptionMixin.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/BatchJobFieldDelimiterOptionMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/BatchJobFieldNamesOptionMixin.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/BatchJobFieldNamesOptionMixin.java index 8bf6a5fe5..5d64dd866 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/BatchJobFieldNamesOptionMixin.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/BatchJobFieldNamesOptionMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/BatchJobResourcesOptionMixin.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/BatchJobResourcesOptionMixin.java index cfadf7d1d..4c2515e37 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/BatchJobResourcesOptionMixin.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/BatchJobResourcesOptionMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/BatchJobRestartableOptionMixin.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/BatchJobRestartableOptionMixin.java index 4c2c7759e..9e44005de 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/BatchJobRestartableOptionMixin.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/BatchJobRestartableOptionMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/BatchJobSinglestepPartitionSupportOptionMixin.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/BatchJobSinglestepPartitionSupportOptionMixin.java index 948a1bd30..8ce11c824 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/BatchJobSinglestepPartitionSupportOptionMixin.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/BatchJobSinglestepPartitionSupportOptionMixin.java @@ -6,7 +6,7 @@ * * you may not use this file except in compliance with the License. * * You may obtain a copy of the License at * * - * * http://www.apache.org/licenses/LICENSE-2.0 + * * https://www.apache.org/licenses/LICENSE-2.0 * * * * Unless required by applicable law or agreed to in writing, software * * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/DateFormatMixin.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/DateFormatMixin.java index 586d1301a..104921675 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/DateFormatMixin.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/DateFormatMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/ExpressionOrScriptMixin.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/ExpressionOrScriptMixin.java index 78e4c03e6..399a36b20 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/ExpressionOrScriptMixin.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/ExpressionOrScriptMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/FromMongoDbOptionMixin.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/FromMongoDbOptionMixin.java index 541105d5d..99001c970 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/FromMongoDbOptionMixin.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/FromMongoDbOptionMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/FromStringCharsetMixin.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/FromStringCharsetMixin.java index 3ec3f7817..d2844036f 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/FromStringCharsetMixin.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/FromStringCharsetMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/FtpConnectionMixin.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/FtpConnectionMixin.java index e10de26d2..4855393ba 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/FtpConnectionMixin.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/FtpConnectionMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/HadoopConfigurationMixin.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/HadoopConfigurationMixin.java index b71ec6dae..dcfd6535f 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/HadoopConfigurationMixin.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/HadoopConfigurationMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/IntoMongoDbOptionMixin.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/IntoMongoDbOptionMixin.java index f9aa55d0b..d7bdf8201 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/IntoMongoDbOptionMixin.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/IntoMongoDbOptionMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/MappedRequestHeadersMixin.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/MappedRequestHeadersMixin.java index db7b67996..f631d6946 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/MappedRequestHeadersMixin.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/MappedRequestHeadersMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/MappedResponseHeadersMixin.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/MappedResponseHeadersMixin.java index 3f2798c99..e6ee3805d 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/MappedResponseHeadersMixin.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/MappedResponseHeadersMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/MapreduceConfigurationMixin.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/MapreduceConfigurationMixin.java index 3723d392e..b161bdd4a 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/MapreduceConfigurationMixin.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/MapreduceConfigurationMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/MaxMessagesDefaultOneMixin.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/MaxMessagesDefaultOneMixin.java index e44ad1dd7..822103b9b 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/MaxMessagesDefaultOneMixin.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/MaxMessagesDefaultOneMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/MaxMessagesDefaultUnlimitedMixin.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/MaxMessagesDefaultUnlimitedMixin.java index 8655b972f..13c4d43f3 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/MaxMessagesDefaultUnlimitedMixin.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/MaxMessagesDefaultUnlimitedMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/MongoDbConnectionMixin.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/MongoDbConnectionMixin.java index 177735b08..129e79a0b 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/MongoDbConnectionMixin.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/MongoDbConnectionMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/PeriodicTriggerMixin.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/PeriodicTriggerMixin.java index c278b4855..3c80eba75 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/PeriodicTriggerMixin.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/PeriodicTriggerMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/ScriptMixin.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/ScriptMixin.java index af25925c4..ee87276d0 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/ScriptMixin.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/ScriptMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/ToStringCharsetMixin.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/ToStringCharsetMixin.java index b6018e52c..8b9f61e6f 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/ToStringCharsetMixin.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/mixins/ToStringCharsetMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/spi/Mixin.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/spi/Mixin.java index cab5f8cb7..a2c43d935 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/spi/Mixin.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/spi/Mixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/spi/ModuleOption.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/spi/ModuleOption.java index 09e870e1d..aa70f7d6e 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/spi/ModuleOption.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/spi/ModuleOption.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/spi/ModulePlaceholders.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/spi/ModulePlaceholders.java index 5a11ac594..02d23c296 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/spi/ModulePlaceholders.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/spi/ModulePlaceholders.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/spi/ProfileNamesProvider.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/spi/ProfileNamesProvider.java index 181fcbca0..7630fbada 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/spi/ProfileNamesProvider.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/spi/ProfileNamesProvider.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/spi/ValidationGroupsProvider.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/spi/ValidationGroupsProvider.java index f8ff8f99c..4faccc29a 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/spi/ValidationGroupsProvider.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/spi/ValidationGroupsProvider.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/types/Password.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/types/Password.java index 06d8d901f..1f5b9b4e2 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/types/Password.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/types/Password.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/validation/CronExpression.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/validation/CronExpression.java index bd5ce62c7..5ccfc1de8 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/validation/CronExpression.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/validation/CronExpression.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/validation/DateFormat.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/validation/DateFormat.java index 0fdc299e6..e41d28bd0 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/validation/DateFormat.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/validation/DateFormat.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/validation/DateWithCustomFormat.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/validation/DateWithCustomFormat.java index e2ba238a8..ed49e46c6 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/validation/DateWithCustomFormat.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/validation/DateWithCustomFormat.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/validation/Exclusives.java b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/validation/Exclusives.java index f956e45d4..da095c17d 100644 --- a/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/validation/Exclusives.java +++ b/spring-xd-module-spi/src/main/java/org/springframework/xd/module/options/validation/Exclusives.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/test/java/org/springframework/xd/module/options/types/PasswordTests.java b/spring-xd-module-spi/src/test/java/org/springframework/xd/module/options/types/PasswordTests.java index fe38b9434..3864fe4ad 100644 --- a/spring-xd-module-spi/src/test/java/org/springframework/xd/module/options/types/PasswordTests.java +++ b/spring-xd-module-spi/src/test/java/org/springframework/xd/module/options/types/PasswordTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/test/java/org/springframework/xd/module/options/validation/CronValidatorTests.java b/spring-xd-module-spi/src/test/java/org/springframework/xd/module/options/validation/CronValidatorTests.java index 599133f38..ff913f346 100644 --- a/spring-xd-module-spi/src/test/java/org/springframework/xd/module/options/validation/CronValidatorTests.java +++ b/spring-xd-module-spi/src/test/java/org/springframework/xd/module/options/validation/CronValidatorTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/test/java/org/springframework/xd/module/options/validation/DateFormatValidatorTests.java b/spring-xd-module-spi/src/test/java/org/springframework/xd/module/options/validation/DateFormatValidatorTests.java index bca55ac41..d570eb2b3 100644 --- a/spring-xd-module-spi/src/test/java/org/springframework/xd/module/options/validation/DateFormatValidatorTests.java +++ b/spring-xd-module-spi/src/test/java/org/springframework/xd/module/options/validation/DateFormatValidatorTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module-spi/src/test/java/org/springframework/xd/module/options/validation/DateWithCustomFormatTests.java b/spring-xd-module-spi/src/test/java/org/springframework/xd/module/options/validation/DateWithCustomFormatTests.java index 1b6838ba4..7015bc21e 100644 --- a/spring-xd-module-spi/src/test/java/org/springframework/xd/module/options/validation/DateWithCustomFormatTests.java +++ b/spring-xd-module-spi/src/test/java/org/springframework/xd/module/options/validation/DateWithCustomFormatTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/CompositeModuleDefinition.java b/spring-xd-module/src/main/java/org/springframework/xd/module/CompositeModuleDefinition.java index fdb8cd616..0c37a6e9c 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/CompositeModuleDefinition.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/CompositeModuleDefinition.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/ModuleDefinition.java b/spring-xd-module/src/main/java/org/springframework/xd/module/ModuleDefinition.java index 6bbb91071..34135241d 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/ModuleDefinition.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/ModuleDefinition.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/ModuleDefinitions.java b/spring-xd-module/src/main/java/org/springframework/xd/module/ModuleDefinitions.java index 5951a3ef4..335c0dc55 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/ModuleDefinitions.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/ModuleDefinitions.java @@ -6,7 +6,7 @@ * * you may not use this file except in compliance with the License. * * You may obtain a copy of the License at * * - * * http://www.apache.org/licenses/LICENSE-2.0 + * * https://www.apache.org/licenses/LICENSE-2.0 * * * * Unless required by applicable law or agreed to in writing, software * * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/ModuleDeploymentProperties.java b/spring-xd-module/src/main/java/org/springframework/xd/module/ModuleDeploymentProperties.java index f8fba6c27..a670ccd21 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/ModuleDeploymentProperties.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/ModuleDeploymentProperties.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/ModuleDescriptor.java b/spring-xd-module/src/main/java/org/springframework/xd/module/ModuleDescriptor.java index 9a9155633..94ca05362 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/ModuleDescriptor.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/ModuleDescriptor.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/ModuleType.java b/spring-xd-module/src/main/java/org/springframework/xd/module/ModuleType.java index f56b93e87..d8550dbba 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/ModuleType.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/ModuleType.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/RuntimeModuleDeploymentProperties.java b/spring-xd-module/src/main/java/org/springframework/xd/module/RuntimeModuleDeploymentProperties.java index 4e05be3e4..ba27d470f 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/RuntimeModuleDeploymentProperties.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/RuntimeModuleDeploymentProperties.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/SimpleModuleDefinition.java b/spring-xd-module/src/main/java/org/springframework/xd/module/SimpleModuleDefinition.java index 6cd46ef5a..2b1b55251 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/SimpleModuleDefinition.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/SimpleModuleDefinition.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/core/AbstractModule.java b/spring-xd-module/src/main/java/org/springframework/xd/module/core/AbstractModule.java index 6639b9845..16f78a659 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/core/AbstractModule.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/core/AbstractModule.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/core/CompositeModule.java b/spring-xd-module/src/main/java/org/springframework/xd/module/core/CompositeModule.java index 001c826cb..76d1240ca 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/core/CompositeModule.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/core/CompositeModule.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/core/JavaConfiguredModule.java b/spring-xd-module/src/main/java/org/springframework/xd/module/core/JavaConfiguredModule.java index 0d950c56f..2cc2477b8 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/core/JavaConfiguredModule.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/core/JavaConfiguredModule.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/core/Module.java b/spring-xd-module/src/main/java/org/springframework/xd/module/core/Module.java index b746b68e6..faec67026 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/core/Module.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/core/Module.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/core/ModuleEnvironment.java b/spring-xd-module/src/main/java/org/springframework/xd/module/core/ModuleEnvironment.java index e6b33b8e1..e27848209 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/core/ModuleEnvironment.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/core/ModuleEnvironment.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/core/ModuleFactory.java b/spring-xd-module/src/main/java/org/springframework/xd/module/core/ModuleFactory.java index 0e83c68c2..071dddaa9 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/core/ModuleFactory.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/core/ModuleFactory.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/core/NonBindingResourceConfiguredModule.java b/spring-xd-module/src/main/java/org/springframework/xd/module/core/NonBindingResourceConfiguredModule.java index d393dd6a2..c6a241b80 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/core/NonBindingResourceConfiguredModule.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/core/NonBindingResourceConfiguredModule.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/core/Plugin.java b/spring-xd-module/src/main/java/org/springframework/xd/module/core/Plugin.java index ff4af5334..c0480657b 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/core/Plugin.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/core/Plugin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/core/ResourceConfiguredModule.java b/spring-xd-module/src/main/java/org/springframework/xd/module/core/ResourceConfiguredModule.java index d7ff1f426..465116ae1 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/core/ResourceConfiguredModule.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/core/ResourceConfiguredModule.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/core/SimpleModule.java b/spring-xd-module/src/main/java/org/springframework/xd/module/core/SimpleModule.java index cd46c43da..197ff49e1 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/core/SimpleModule.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/core/SimpleModule.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/info/DefaultSimpleModuleInformationResolver.java b/spring-xd-module/src/main/java/org/springframework/xd/module/info/DefaultSimpleModuleInformationResolver.java index f288cb6e0..b1311c6bd 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/info/DefaultSimpleModuleInformationResolver.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/info/DefaultSimpleModuleInformationResolver.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/info/DelegatingModuleInformationResolver.java b/spring-xd-module/src/main/java/org/springframework/xd/module/info/DelegatingModuleInformationResolver.java index 5fdca08ec..29f9302a1 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/info/DelegatingModuleInformationResolver.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/info/DelegatingModuleInformationResolver.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/info/ModuleInformation.java b/spring-xd-module/src/main/java/org/springframework/xd/module/info/ModuleInformation.java index ee8e05051..07f685d35 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/info/ModuleInformation.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/info/ModuleInformation.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/info/ModuleInformationResolver.java b/spring-xd-module/src/main/java/org/springframework/xd/module/info/ModuleInformationResolver.java index d66ca6d88..39cc18de7 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/info/ModuleInformationResolver.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/info/ModuleInformationResolver.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/options/DefaultModuleOptionsMetadataCollector.java b/spring-xd-module/src/main/java/org/springframework/xd/module/options/DefaultModuleOptionsMetadataCollector.java index 2bea59c0c..cf53124fb 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/options/DefaultModuleOptionsMetadataCollector.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/options/DefaultModuleOptionsMetadataCollector.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/options/DefaultModuleOptionsMetadataResolver.java b/spring-xd-module/src/main/java/org/springframework/xd/module/options/DefaultModuleOptionsMetadataResolver.java index a4cc0f6be..246a78e9e 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/options/DefaultModuleOptionsMetadataResolver.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/options/DefaultModuleOptionsMetadataResolver.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/options/DelegatingModuleOptionsMetadataResolver.java b/spring-xd-module/src/main/java/org/springframework/xd/module/options/DelegatingModuleOptionsMetadataResolver.java index 07a3283fe..2e043d5a3 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/options/DelegatingModuleOptionsMetadataResolver.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/options/DelegatingModuleOptionsMetadataResolver.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/options/EnvironmentAwareModuleOptionsMetadataResolver.java b/spring-xd-module/src/main/java/org/springframework/xd/module/options/EnvironmentAwareModuleOptionsMetadataResolver.java index a9046d9b8..041299787 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/options/EnvironmentAwareModuleOptionsMetadataResolver.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/options/EnvironmentAwareModuleOptionsMetadataResolver.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/options/FlattenedCompositeModuleOptionsMetadata.java b/spring-xd-module/src/main/java/org/springframework/xd/module/options/FlattenedCompositeModuleOptionsMetadata.java index 622f0ad5f..18cebd467 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/options/FlattenedCompositeModuleOptionsMetadata.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/options/FlattenedCompositeModuleOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/options/HierarchicalCompositeModuleOptionsMetadata.java b/spring-xd-module/src/main/java/org/springframework/xd/module/options/HierarchicalCompositeModuleOptionsMetadata.java index 9c860748b..87375b70f 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/options/HierarchicalCompositeModuleOptionsMetadata.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/options/HierarchicalCompositeModuleOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/options/ModuleOption.java b/spring-xd-module/src/main/java/org/springframework/xd/module/options/ModuleOption.java index e26a6ee44..3aef93227 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/options/ModuleOption.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/options/ModuleOption.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/options/ModuleOptions.java b/spring-xd-module/src/main/java/org/springframework/xd/module/options/ModuleOptions.java index c8d024112..c73c3c287 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/options/ModuleOptions.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/options/ModuleOptions.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/options/ModuleOptionsMetadata.java b/spring-xd-module/src/main/java/org/springframework/xd/module/options/ModuleOptionsMetadata.java index 65a8f777e..9ebc73c35 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/options/ModuleOptionsMetadata.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/options/ModuleOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/options/ModuleOptionsMetadataResolver.java b/spring-xd-module/src/main/java/org/springframework/xd/module/options/ModuleOptionsMetadataResolver.java index 8cd526d19..41056167e 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/options/ModuleOptionsMetadataResolver.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/options/ModuleOptionsMetadataResolver.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/options/ModuleUtils.java b/spring-xd-module/src/main/java/org/springframework/xd/module/options/ModuleUtils.java index 2490aec93..200e8d29b 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/options/ModuleUtils.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/options/ModuleUtils.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/options/PassthruModuleOptionsMetadata.java b/spring-xd-module/src/main/java/org/springframework/xd/module/options/PassthruModuleOptionsMetadata.java index 4aac21a9e..bb9a150c0 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/options/PassthruModuleOptionsMetadata.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/options/PassthruModuleOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/options/PojoModuleOptionsMetadata.java b/spring-xd-module/src/main/java/org/springframework/xd/module/options/PojoModuleOptionsMetadata.java index a743d498d..c7733bef8 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/options/PojoModuleOptionsMetadata.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/options/PojoModuleOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/options/PrefixNarrowingModuleOptions.java b/spring-xd-module/src/main/java/org/springframework/xd/module/options/PrefixNarrowingModuleOptions.java index 7d2d66645..74b70590b 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/options/PrefixNarrowingModuleOptions.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/options/PrefixNarrowingModuleOptions.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/options/SimpleModuleOptionsMetadata.java b/spring-xd-module/src/main/java/org/springframework/xd/module/options/SimpleModuleOptionsMetadata.java index 51fbfd422..d02975190 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/options/SimpleModuleOptionsMetadata.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/options/SimpleModuleOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/options/support/StringToEnumIgnoringCaseConverterFactory.java b/spring-xd-module/src/main/java/org/springframework/xd/module/options/support/StringToEnumIgnoringCaseConverterFactory.java index 0d7ddb3a4..f8494670c 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/options/support/StringToEnumIgnoringCaseConverterFactory.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/options/support/StringToEnumIgnoringCaseConverterFactory.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/spark/streaming/package-info.java b/spring-xd-module/src/main/java/org/springframework/xd/module/spark/streaming/package-info.java index 8a63b715c..64595ca3e 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/spark/streaming/package-info.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/spark/streaming/package-info.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/support/ArchiveResourceLoader.java b/spring-xd-module/src/main/java/org/springframework/xd/module/support/ArchiveResourceLoader.java index e65b48324..3902393e1 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/support/ArchiveResourceLoader.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/support/ArchiveResourceLoader.java @@ -6,7 +6,7 @@ * * you may not use this file except in compliance with the License. * * You may obtain a copy of the License at * * - * * http://www.apache.org/licenses/LICENSE-2.0 + * * https://www.apache.org/licenses/LICENSE-2.0 * * * * Unless required by applicable law or agreed to in writing, software * * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/support/DateTrigger.java b/spring-xd-module/src/main/java/org/springframework/xd/module/support/DateTrigger.java index 559b68ae3..8b74237e5 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/support/DateTrigger.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/support/DateTrigger.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/support/NestedArchiveResource.java b/spring-xd-module/src/main/java/org/springframework/xd/module/support/NestedArchiveResource.java index 2dc7e720d..5c9c77810 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/support/NestedArchiveResource.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/support/NestedArchiveResource.java @@ -6,7 +6,7 @@ * * you may not use this file except in compliance with the License. * * You may obtain a copy of the License at * * - * * http://www.apache.org/licenses/LICENSE-2.0 + * * https://www.apache.org/licenses/LICENSE-2.0 * * * * Unless required by applicable law or agreed to in writing, software * * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/support/NullClassLoader.java b/spring-xd-module/src/main/java/org/springframework/xd/module/support/NullClassLoader.java index 8ca18d099..273dcd62e 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/support/NullClassLoader.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/support/NullClassLoader.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/main/java/org/springframework/xd/module/support/ParentLastURLClassLoader.java b/spring-xd-module/src/main/java/org/springframework/xd/module/support/ParentLastURLClassLoader.java index cb0ae10a8..70b84375c 100644 --- a/spring-xd-module/src/main/java/org/springframework/xd/module/support/ParentLastURLClassLoader.java +++ b/spring-xd-module/src/main/java/org/springframework/xd/module/support/ParentLastURLClassLoader.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/test/java/org/springframework/xd/module/core/ModuleEnvironmentTests.java b/spring-xd-module/src/test/java/org/springframework/xd/module/core/ModuleEnvironmentTests.java index 77d8f3970..4537f3914 100644 --- a/spring-xd-module/src/test/java/org/springframework/xd/module/core/ModuleEnvironmentTests.java +++ b/spring-xd-module/src/test/java/org/springframework/xd/module/core/ModuleEnvironmentTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/test/java/org/springframework/xd/module/core/ModuleFactoryTests.java b/spring-xd-module/src/test/java/org/springframework/xd/module/core/ModuleFactoryTests.java index 1c23a16e3..25a321f85 100644 --- a/spring-xd-module/src/test/java/org/springframework/xd/module/core/ModuleFactoryTests.java +++ b/spring-xd-module/src/test/java/org/springframework/xd/module/core/ModuleFactoryTests.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/test/java/org/springframework/xd/module/info/DefaultSimpleModuleInformationResolverTests.java b/spring-xd-module/src/test/java/org/springframework/xd/module/info/DefaultSimpleModuleInformationResolverTests.java index 3982fdebb..36556ea30 100644 --- a/spring-xd-module/src/test/java/org/springframework/xd/module/info/DefaultSimpleModuleInformationResolverTests.java +++ b/spring-xd-module/src/test/java/org/springframework/xd/module/info/DefaultSimpleModuleInformationResolverTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/test/java/org/springframework/xd/module/info/DelegatingModuleInformationResolverTests.java b/spring-xd-module/src/test/java/org/springframework/xd/module/info/DelegatingModuleInformationResolverTests.java index 9257858eb..0776cafc4 100644 --- a/spring-xd-module/src/test/java/org/springframework/xd/module/info/DelegatingModuleInformationResolverTests.java +++ b/spring-xd-module/src/test/java/org/springframework/xd/module/info/DelegatingModuleInformationResolverTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/test/java/org/springframework/xd/module/options/AlmostOverlappingPojo.java b/spring-xd-module/src/test/java/org/springframework/xd/module/options/AlmostOverlappingPojo.java index be8f57d98..a37f6d2a7 100644 --- a/spring-xd-module/src/test/java/org/springframework/xd/module/options/AlmostOverlappingPojo.java +++ b/spring-xd-module/src/test/java/org/springframework/xd/module/options/AlmostOverlappingPojo.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/test/java/org/springframework/xd/module/options/BackingPojo.java b/spring-xd-module/src/test/java/org/springframework/xd/module/options/BackingPojo.java index 2415d916d..158e3e1fd 100644 --- a/spring-xd-module/src/test/java/org/springframework/xd/module/options/BackingPojo.java +++ b/spring-xd-module/src/test/java/org/springframework/xd/module/options/BackingPojo.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/test/java/org/springframework/xd/module/options/DefaultModuleOptionsMetadataCollectorTests.java b/spring-xd-module/src/test/java/org/springframework/xd/module/options/DefaultModuleOptionsMetadataCollectorTests.java index 83daee1a0..00fa386d9 100644 --- a/spring-xd-module/src/test/java/org/springframework/xd/module/options/DefaultModuleOptionsMetadataCollectorTests.java +++ b/spring-xd-module/src/test/java/org/springframework/xd/module/options/DefaultModuleOptionsMetadataCollectorTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/test/java/org/springframework/xd/module/options/DefaultModuleOptionsMetadataResolverTests.java b/spring-xd-module/src/test/java/org/springframework/xd/module/options/DefaultModuleOptionsMetadataResolverTests.java index 714d18fb2..d347ff52f 100644 --- a/spring-xd-module/src/test/java/org/springframework/xd/module/options/DefaultModuleOptionsMetadataResolverTests.java +++ b/spring-xd-module/src/test/java/org/springframework/xd/module/options/DefaultModuleOptionsMetadataResolverTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/test/java/org/springframework/xd/module/options/FlattenedCompositeModuleOptionsMetadataTests.java b/spring-xd-module/src/test/java/org/springframework/xd/module/options/FlattenedCompositeModuleOptionsMetadataTests.java index 5153b9acc..b7cec3461 100644 --- a/spring-xd-module/src/test/java/org/springframework/xd/module/options/FlattenedCompositeModuleOptionsMetadataTests.java +++ b/spring-xd-module/src/test/java/org/springframework/xd/module/options/FlattenedCompositeModuleOptionsMetadataTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/test/java/org/springframework/xd/module/options/HierarchicalCompositeModuleOptionsMetadataTests.java b/spring-xd-module/src/test/java/org/springframework/xd/module/options/HierarchicalCompositeModuleOptionsMetadataTests.java index 662457a08..4f43707d0 100644 --- a/spring-xd-module/src/test/java/org/springframework/xd/module/options/HierarchicalCompositeModuleOptionsMetadataTests.java +++ b/spring-xd-module/src/test/java/org/springframework/xd/module/options/HierarchicalCompositeModuleOptionsMetadataTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/test/java/org/springframework/xd/module/options/ModuleOptionMatchers.java b/spring-xd-module/src/test/java/org/springframework/xd/module/options/ModuleOptionMatchers.java index c68dc07f0..8a24963f2 100644 --- a/spring-xd-module/src/test/java/org/springframework/xd/module/options/ModuleOptionMatchers.java +++ b/spring-xd-module/src/test/java/org/springframework/xd/module/options/ModuleOptionMatchers.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/test/java/org/springframework/xd/module/options/OtherBackingPojo.java b/spring-xd-module/src/test/java/org/springframework/xd/module/options/OtherBackingPojo.java index f72b20ced..dc0e32eb1 100644 --- a/spring-xd-module/src/test/java/org/springframework/xd/module/options/OtherBackingPojo.java +++ b/spring-xd-module/src/test/java/org/springframework/xd/module/options/OtherBackingPojo.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/test/java/org/springframework/xd/module/options/OverlappingPojo.java b/spring-xd-module/src/test/java/org/springframework/xd/module/options/OverlappingPojo.java index c751aa53f..c1b803698 100644 --- a/spring-xd-module/src/test/java/org/springframework/xd/module/options/OverlappingPojo.java +++ b/spring-xd-module/src/test/java/org/springframework/xd/module/options/OverlappingPojo.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/test/java/org/springframework/xd/module/options/PojoModuleOptionsMetadataTests.java b/spring-xd-module/src/test/java/org/springframework/xd/module/options/PojoModuleOptionsMetadataTests.java index 1a7aa45e6..fe35295f7 100644 --- a/spring-xd-module/src/test/java/org/springframework/xd/module/options/PojoModuleOptionsMetadataTests.java +++ b/spring-xd-module/src/test/java/org/springframework/xd/module/options/PojoModuleOptionsMetadataTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/test/java/org/springframework/xd/module/options/PojoWithAlmostOverlappingMixins.java b/spring-xd-module/src/test/java/org/springframework/xd/module/options/PojoWithAlmostOverlappingMixins.java index 4de2372b0..63d9dc2f1 100644 --- a/spring-xd-module/src/test/java/org/springframework/xd/module/options/PojoWithAlmostOverlappingMixins.java +++ b/spring-xd-module/src/test/java/org/springframework/xd/module/options/PojoWithAlmostOverlappingMixins.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/test/java/org/springframework/xd/module/options/PojoWithMixin.java b/spring-xd-module/src/test/java/org/springframework/xd/module/options/PojoWithMixin.java index d7ebc07fb..374b5eaf1 100644 --- a/spring-xd-module/src/test/java/org/springframework/xd/module/options/PojoWithMixin.java +++ b/spring-xd-module/src/test/java/org/springframework/xd/module/options/PojoWithMixin.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/test/java/org/springframework/xd/module/options/PojoWithOverlappingMixins.java b/spring-xd-module/src/test/java/org/springframework/xd/module/options/PojoWithOverlappingMixins.java index 1fe934555..3fb6bfd47 100644 --- a/spring-xd-module/src/test/java/org/springframework/xd/module/options/PojoWithOverlappingMixins.java +++ b/spring-xd-module/src/test/java/org/springframework/xd/module/options/PojoWithOverlappingMixins.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/test/java/org/springframework/xd/module/options/PrefixNarrowingModuleOptionsTests.java b/spring-xd-module/src/test/java/org/springframework/xd/module/options/PrefixNarrowingModuleOptionsTests.java index 11beff14a..09277507c 100644 --- a/spring-xd-module/src/test/java/org/springframework/xd/module/options/PrefixNarrowingModuleOptionsTests.java +++ b/spring-xd-module/src/test/java/org/springframework/xd/module/options/PrefixNarrowingModuleOptionsTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/test/java/org/springframework/xd/module/options/SimpleModuleOptionsMetadataTests.java b/spring-xd-module/src/test/java/org/springframework/xd/module/options/SimpleModuleOptionsMetadataTests.java index 65f55edef..0bba1ed73 100644 --- a/spring-xd-module/src/test/java/org/springframework/xd/module/options/SimpleModuleOptionsMetadataTests.java +++ b/spring-xd-module/src/test/java/org/springframework/xd/module/options/SimpleModuleOptionsMetadataTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/test/java/org/springframework/xd/module/support/ArchiveResourceLoaderTests.java b/spring-xd-module/src/test/java/org/springframework/xd/module/support/ArchiveResourceLoaderTests.java index a46a876d3..0da3c452a 100644 --- a/spring-xd-module/src/test/java/org/springframework/xd/module/support/ArchiveResourceLoaderTests.java +++ b/spring-xd-module/src/test/java/org/springframework/xd/module/support/ArchiveResourceLoaderTests.java @@ -6,7 +6,7 @@ * * you may not use this file except in compliance with the License. * * You may obtain a copy of the License at * * - * * http://www.apache.org/licenses/LICENSE-2.0 + * * https://www.apache.org/licenses/LICENSE-2.0 * * * * Unless required by applicable law or agreed to in writing, software * * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/test/java/org/springframework/xd/module/support/DateTriggerTest.java b/spring-xd-module/src/test/java/org/springframework/xd/module/support/DateTriggerTest.java index cb4c69ef6..d0b09c873 100644 --- a/spring-xd-module/src/test/java/org/springframework/xd/module/support/DateTriggerTest.java +++ b/spring-xd-module/src/test/java/org/springframework/xd/module/support/DateTriggerTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/test/java/org/springframework/xd/module/support/ModuleUtilsTests.java b/spring-xd-module/src/test/java/org/springframework/xd/module/support/ModuleUtilsTests.java index 2393f2ace..49cb29134 100644 --- a/spring-xd-module/src/test/java/org/springframework/xd/module/support/ModuleUtilsTests.java +++ b/spring-xd-module/src/test/java/org/springframework/xd/module/support/ModuleUtilsTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/test/java/org/springframework/xd/module/support/ParentLastURLClassLoaderTests.java b/spring-xd-module/src/test/java/org/springframework/xd/module/support/ParentLastURLClassLoaderTests.java index a9f641917..f82bbcf32 100644 --- a/spring-xd-module/src/test/java/org/springframework/xd/module/support/ParentLastURLClassLoaderTests.java +++ b/spring-xd-module/src/test/java/org/springframework/xd/module/support/ParentLastURLClassLoaderTests.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-module/src/test/resources/ModuleUtilsTests/dynamic_classpath/source/foobar/config/foobar.properties b/spring-xd-module/src/test/resources/ModuleUtilsTests/dynamic_classpath/source/foobar/config/foobar.properties index 7ccf4dff8..2f7204301 100644 --- a/spring-xd-module/src/test/resources/ModuleUtilsTests/dynamic_classpath/source/foobar/config/foobar.properties +++ b/spring-xd-module/src/test/resources/ModuleUtilsTests/dynamic_classpath/source/foobar/config/foobar.properties @@ -5,7 +5,7 @@ # you may not use this file except in compliance with the License. # You may obtain a copy of the License at # -# http://www.apache.org/licenses/LICENSE-2.0 +# https://www.apache.org/licenses/LICENSE-2.0 # # Unless required by applicable law or agreed to in writing, software # distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-reactor/src/main/java/org/springframework/xd/reactor/AbstractReactorMessageHandler.java b/spring-xd-reactor/src/main/java/org/springframework/xd/reactor/AbstractReactorMessageHandler.java index c81133bd8..809775ba6 100644 --- a/spring-xd-reactor/src/main/java/org/springframework/xd/reactor/AbstractReactorMessageHandler.java +++ b/spring-xd-reactor/src/main/java/org/springframework/xd/reactor/AbstractReactorMessageHandler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-reactor/src/main/java/org/springframework/xd/reactor/BroadcasterMessageHandler.java b/spring-xd-reactor/src/main/java/org/springframework/xd/reactor/BroadcasterMessageHandler.java index 010f3caac..735e2e1b4 100644 --- a/spring-xd-reactor/src/main/java/org/springframework/xd/reactor/BroadcasterMessageHandler.java +++ b/spring-xd-reactor/src/main/java/org/springframework/xd/reactor/BroadcasterMessageHandler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-reactor/src/main/java/org/springframework/xd/reactor/MultipleBroadcasterMessageHandler.java b/spring-xd-reactor/src/main/java/org/springframework/xd/reactor/MultipleBroadcasterMessageHandler.java index 97bfc4c22..ee1918dd5 100644 --- a/spring-xd-reactor/src/main/java/org/springframework/xd/reactor/MultipleBroadcasterMessageHandler.java +++ b/spring-xd-reactor/src/main/java/org/springframework/xd/reactor/MultipleBroadcasterMessageHandler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-reactor/src/main/java/org/springframework/xd/reactor/Processor.java b/spring-xd-reactor/src/main/java/org/springframework/xd/reactor/Processor.java index b37b3a554..1835be67b 100644 --- a/spring-xd-reactor/src/main/java/org/springframework/xd/reactor/Processor.java +++ b/spring-xd-reactor/src/main/java/org/springframework/xd/reactor/Processor.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-reactor/src/main/java/org/springframework/xd/reactor/ReactorReflectionUtils.java b/spring-xd-reactor/src/main/java/org/springframework/xd/reactor/ReactorReflectionUtils.java index 699097dcb..a32dbaf4e 100644 --- a/spring-xd-reactor/src/main/java/org/springframework/xd/reactor/ReactorReflectionUtils.java +++ b/spring-xd-reactor/src/main/java/org/springframework/xd/reactor/ReactorReflectionUtils.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/AbstractMessageHandlerTests.java b/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/AbstractMessageHandlerTests.java index 833fc229e..661026425 100644 --- a/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/AbstractMessageHandlerTests.java +++ b/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/AbstractMessageHandlerTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/AbstractPongStringProcessor.java b/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/AbstractPongStringProcessor.java index 5b44d6665..1039d42cd 100644 --- a/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/AbstractPongStringProcessor.java +++ b/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/AbstractPongStringProcessor.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/AbstractRawTypeProcessor.java b/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/AbstractRawTypeProcessor.java index 0eece0c5f..c4f130eac 100644 --- a/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/AbstractRawTypeProcessor.java +++ b/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/AbstractRawTypeProcessor.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/AdditionalInterface.java b/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/AdditionalInterface.java index 1166c88f0..707e1a4ce 100644 --- a/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/AdditionalInterface.java +++ b/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/AdditionalInterface.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/BroadcasterMessageHandlerTests.java b/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/BroadcasterMessageHandlerTests.java index c877ed294..c89504fce 100644 --- a/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/BroadcasterMessageHandlerTests.java +++ b/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/BroadcasterMessageHandlerTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/MultipleBroadcasterMessageHandlerTests.java b/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/MultipleBroadcasterMessageHandlerTests.java index 23a7c787e..54a1c48bd 100644 --- a/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/MultipleBroadcasterMessageHandlerTests.java +++ b/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/MultipleBroadcasterMessageHandlerTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/PongMessageProcessor.java b/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/PongMessageProcessor.java index 15f6b0f00..6fa79d531 100644 --- a/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/PongMessageProcessor.java +++ b/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/PongMessageProcessor.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/PongRawTypeProcessor.java b/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/PongRawTypeProcessor.java index 3d0986404..b0cf98993 100644 --- a/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/PongRawTypeProcessor.java +++ b/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/PongRawTypeProcessor.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/PongStringProcessor.java b/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/PongStringProcessor.java index a25e83e65..ab316b76d 100644 --- a/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/PongStringProcessor.java +++ b/spring-xd-reactor/src/test/java/org/springframework/xd/reactor/PongStringProcessor.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/AggregateCounterOperations.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/AggregateCounterOperations.java index b6e642246..ce8b3548d 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/AggregateCounterOperations.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/AggregateCounterOperations.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/CompletionOperations.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/CompletionOperations.java index 1fbc56946..195678ebf 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/CompletionOperations.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/CompletionOperations.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/CounterOperations.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/CounterOperations.java index 5140ac26c..528bf9396 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/CounterOperations.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/CounterOperations.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/FieldValueCounterOperations.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/FieldValueCounterOperations.java index d99983143..0f231f793 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/FieldValueCounterOperations.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/FieldValueCounterOperations.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/GaugeOperations.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/GaugeOperations.java index 53a2c7a02..c57e6aafe 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/GaugeOperations.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/GaugeOperations.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/JobOperations.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/JobOperations.java index d35895bef..5746553e9 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/JobOperations.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/JobOperations.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/ModuleOperations.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/ModuleOperations.java index 099249069..1eeef943b 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/ModuleOperations.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/ModuleOperations.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/ResourceOperations.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/ResourceOperations.java index 053741bac..56b857ea1 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/ResourceOperations.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/ResourceOperations.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/RichGaugeOperations.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/RichGaugeOperations.java index 1731bdfd7..fb040b465 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/RichGaugeOperations.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/RichGaugeOperations.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/RuntimeOperations.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/RuntimeOperations.java index 35a6b1804..56564907f 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/RuntimeOperations.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/RuntimeOperations.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/SpringXDOperations.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/SpringXDOperations.java index 52408b92a..f64993340 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/SpringXDOperations.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/SpringXDOperations.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/StreamOperations.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/StreamOperations.java index f77060fb0..84aa4ac0c 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/StreamOperations.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/StreamOperations.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/AbstractMetricTemplate.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/AbstractMetricTemplate.java index a624d936c..74ce7e00b 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/AbstractMetricTemplate.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/AbstractMetricTemplate.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/AbstractResourceTemplate.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/AbstractResourceTemplate.java index 5092e14a6..7b250bde7 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/AbstractResourceTemplate.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/AbstractResourceTemplate.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/AbstractSingleMetricTemplate.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/AbstractSingleMetricTemplate.java index 574b1eb61..d5384af9e 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/AbstractSingleMetricTemplate.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/AbstractSingleMetricTemplate.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/AbstractTemplate.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/AbstractTemplate.java index 99b8f5049..e108b66cf 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/AbstractTemplate.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/AbstractTemplate.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/AggregateCounterTemplate.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/AggregateCounterTemplate.java index 32115c0cf..022ee56e2 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/AggregateCounterTemplate.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/AggregateCounterTemplate.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/CompletionTemplate.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/CompletionTemplate.java index 1aee8496c..608210166 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/CompletionTemplate.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/CompletionTemplate.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/CounterTemplate.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/CounterTemplate.java index d3eaa9f1c..8221bcba7 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/CounterTemplate.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/CounterTemplate.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/FieldValueCounterTemplate.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/FieldValueCounterTemplate.java index 000479d8d..1c76815b4 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/FieldValueCounterTemplate.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/FieldValueCounterTemplate.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/GaugeTemplate.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/GaugeTemplate.java index fd4a02a42..7679212b3 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/GaugeTemplate.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/GaugeTemplate.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/JobTemplate.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/JobTemplate.java index b6f908c21..eb7379a21 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/JobTemplate.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/JobTemplate.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/ModuleTemplate.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/ModuleTemplate.java index efc5cad3c..523316a72 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/ModuleTemplate.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/ModuleTemplate.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/RichGaugeTemplate.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/RichGaugeTemplate.java index d67085aea..8c3ecb02c 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/RichGaugeTemplate.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/RichGaugeTemplate.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/RuntimeTemplate.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/RuntimeTemplate.java index d647930ba..e0372205a 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/RuntimeTemplate.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/RuntimeTemplate.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/SpringXDException.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/SpringXDException.java index 6ea6eee8a..d0ebfdf63 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/SpringXDException.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/SpringXDException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/SpringXDTemplate.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/SpringXDTemplate.java index e6452314d..f13c003fe 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/SpringXDTemplate.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/SpringXDTemplate.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/StreamTemplate.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/StreamTemplate.java index 0cc9477c0..df2544ef8 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/StreamTemplate.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/StreamTemplate.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/VndErrorResponseErrorHandler.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/VndErrorResponseErrorHandler.java index 0eda01e23..9f88957de 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/VndErrorResponseErrorHandler.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/VndErrorResponseErrorHandler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/ExecutionContextJacksonMixIn.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/ExecutionContextJacksonMixIn.java index 554c1274b..cb07d186c 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/ExecutionContextJacksonMixIn.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/ExecutionContextJacksonMixIn.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/ExitStatusJacksonMixIn.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/ExitStatusJacksonMixIn.java index dd775c3ce..f55bf503a 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/ExitStatusJacksonMixIn.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/ExitStatusJacksonMixIn.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/JobExecutionJacksonMixIn.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/JobExecutionJacksonMixIn.java index 5c0897ffa..7e08f3033 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/JobExecutionJacksonMixIn.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/JobExecutionJacksonMixIn.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/JobInstanceJacksonMixIn.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/JobInstanceJacksonMixIn.java index 1e703c22f..9b29ca1f2 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/JobInstanceJacksonMixIn.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/JobInstanceJacksonMixIn.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/JobParameterJacksonDeserializer.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/JobParameterJacksonDeserializer.java index 6451b144c..049195c72 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/JobParameterJacksonDeserializer.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/JobParameterJacksonDeserializer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/JobParameterJacksonMixIn.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/JobParameterJacksonMixIn.java index 2acd75434..8cdbdb98a 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/JobParameterJacksonMixIn.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/JobParameterJacksonMixIn.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/JobParametersJacksonMixIn.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/JobParametersJacksonMixIn.java index 85723784d..d44bfc8f2 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/JobParametersJacksonMixIn.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/JobParametersJacksonMixIn.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/StepExecutionHistoryJacksonMixIn.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/StepExecutionHistoryJacksonMixIn.java index 8bee40dd6..ce0d91575 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/StepExecutionHistoryJacksonMixIn.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/StepExecutionHistoryJacksonMixIn.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/StepExecutionJacksonMixIn.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/StepExecutionJacksonMixIn.java index 39f15c67b..6ab85aad2 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/StepExecutionJacksonMixIn.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/StepExecutionJacksonMixIn.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/package-info.java b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/package-info.java index 63ab0a23b..ff35338f4 100644 --- a/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/package-info.java +++ b/spring-xd-rest-client/src/main/java/org/springframework/xd/rest/client/impl/support/package-info.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/test/java/org/springframework/xd/rest/client/impl/JobExecutionDeserializationTests.java b/spring-xd-rest-client/src/test/java/org/springframework/xd/rest/client/impl/JobExecutionDeserializationTests.java index 97c450572..365a1821a 100644 --- a/spring-xd-rest-client/src/test/java/org/springframework/xd/rest/client/impl/JobExecutionDeserializationTests.java +++ b/spring-xd-rest-client/src/test/java/org/springframework/xd/rest/client/impl/JobExecutionDeserializationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/test/java/org/springframework/xd/rest/client/impl/JobTemplateTests.java b/spring-xd-rest-client/src/test/java/org/springframework/xd/rest/client/impl/JobTemplateTests.java index 47d6ac96d..dcea7fea8 100644 --- a/spring-xd-rest-client/src/test/java/org/springframework/xd/rest/client/impl/JobTemplateTests.java +++ b/spring-xd-rest-client/src/test/java/org/springframework/xd/rest/client/impl/JobTemplateTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-client/src/test/java/org/springframework/xd/rest/client/impl/StreamTemplateTests.java b/spring-xd-rest-client/src/test/java/org/springframework/xd/rest/client/impl/StreamTemplateTests.java index a9a53c86a..5311a7f71 100644 --- a/spring-xd-rest-client/src/test/java/org/springframework/xd/rest/client/impl/StreamTemplateTests.java +++ b/spring-xd-rest-client/src/test/java/org/springframework/xd/rest/client/impl/StreamTemplateTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/CompletionKind.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/CompletionKind.java index acfacb33b..71f8b2fe7 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/CompletionKind.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/CompletionKind.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/DeployableResource.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/DeployableResource.java index 4594b9e53..f073a137e 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/DeployableResource.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/DeployableResource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/DetailedContainerResource.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/DetailedContainerResource.java index f784040ad..8c9bd82c9 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/DetailedContainerResource.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/DetailedContainerResource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/DetailedJobInfoResource.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/DetailedJobInfoResource.java index ace3a20c9..c0caad812 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/DetailedJobInfoResource.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/DetailedJobInfoResource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/DetailedModuleDefinitionResource.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/DetailedModuleDefinitionResource.java index 9b3a87eee..cbdd2ef21 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/DetailedModuleDefinitionResource.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/DetailedModuleDefinitionResource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/DocumentParseResultResource.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/DocumentParseResultResource.java index 94bfeec04..6451373f9 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/DocumentParseResultResource.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/DocumentParseResultResource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/JobDefinitionResource.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/JobDefinitionResource.java index 8669ea8f2..f01142bce 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/JobDefinitionResource.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/JobDefinitionResource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/JobExecutionInfoResource.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/JobExecutionInfoResource.java index 448d8d99e..be941c209 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/JobExecutionInfoResource.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/JobExecutionInfoResource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/JobInfoResource.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/JobInfoResource.java index 81a979f9c..ac4366f67 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/JobInfoResource.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/JobInfoResource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/JobInstanceInfoResource.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/JobInstanceInfoResource.java index a0061672f..b5ab615d3 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/JobInstanceInfoResource.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/JobInstanceInfoResource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/ModuleDefinitionResource.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/ModuleDefinitionResource.java index c78b5c1d8..7c211c573 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/ModuleDefinitionResource.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/ModuleDefinitionResource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/ModuleMetadataResource.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/ModuleMetadataResource.java index 5c7a4bc21..5e3471edc 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/ModuleMetadataResource.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/ModuleMetadataResource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/NamedResource.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/NamedResource.java index 7d843b1c1..383ef0f03 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/NamedResource.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/NamedResource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/RESTDeploymentState.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/RESTDeploymentState.java index 80ffdbb6b..0edb1c5f4 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/RESTDeploymentState.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/RESTDeploymentState.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/RESTModuleType.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/RESTModuleType.java index 23588a9c3..d4441ffe8 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/RESTModuleType.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/RESTModuleType.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/StepExecutionInfoResource.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/StepExecutionInfoResource.java index cc9e09db3..bd1146862 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/StepExecutionInfoResource.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/StepExecutionInfoResource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/StepExecutionProgressInfoResource.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/StepExecutionProgressInfoResource.java index bc91d11d6..58589420d 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/StepExecutionProgressInfoResource.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/StepExecutionProgressInfoResource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/StreamDefinitionResource.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/StreamDefinitionResource.java index 7a4dd2f70..60bcc9771 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/StreamDefinitionResource.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/StreamDefinitionResource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/XDRuntime.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/XDRuntime.java index 42fe081f1..5d2342363 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/XDRuntime.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/XDRuntime.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/meta/VersionResource.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/meta/VersionResource.java index 91d4329d8..261682fdc 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/meta/VersionResource.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/meta/VersionResource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/metrics/AggregateCountsResource.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/metrics/AggregateCountsResource.java index 08a81551a..ad0b038f9 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/metrics/AggregateCountsResource.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/metrics/AggregateCountsResource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/metrics/CounterResource.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/metrics/CounterResource.java index b4e52d334..4d92b273e 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/metrics/CounterResource.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/metrics/CounterResource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/metrics/FieldValueCounterResource.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/metrics/FieldValueCounterResource.java index 653826a51..4d0e19ab7 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/metrics/FieldValueCounterResource.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/metrics/FieldValueCounterResource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/metrics/GaugeResource.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/metrics/GaugeResource.java index ce49bd4b8..a8c1a5c42 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/metrics/GaugeResource.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/metrics/GaugeResource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/metrics/MetricResource.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/metrics/MetricResource.java index 995c61db1..d31bc6cf2 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/metrics/MetricResource.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/metrics/MetricResource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/metrics/RichGaugeResource.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/metrics/RichGaugeResource.java index 10b02ffb3..e978dda45 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/metrics/RichGaugeResource.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/metrics/RichGaugeResource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/security/SecurityInfoResource.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/security/SecurityInfoResource.java index 0ed5f197f..2d8eb2b1c 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/security/SecurityInfoResource.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/security/SecurityInfoResource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/support/DeploymentPropertiesFormat.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/support/DeploymentPropertiesFormat.java index 1cd36db2f..5c06a9f75 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/support/DeploymentPropertiesFormat.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/support/DeploymentPropertiesFormat.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/support/RestTemplateMessageConverterUtil.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/support/RestTemplateMessageConverterUtil.java index a2245c2a8..64060fcc7 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/support/RestTemplateMessageConverterUtil.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/support/RestTemplateMessageConverterUtil.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/util/ISO8601DateFormatWithMilliSeconds.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/util/ISO8601DateFormatWithMilliSeconds.java index 6f1f46857..98cd20adb 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/util/ISO8601DateFormatWithMilliSeconds.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/util/ISO8601DateFormatWithMilliSeconds.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/util/TimeUtils.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/util/TimeUtils.java index 79bb1bea7..46c50b05a 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/util/TimeUtils.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/util/TimeUtils.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/validation/CronValidation.java b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/validation/CronValidation.java index 4f31f73dd..da96318b8 100644 --- a/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/validation/CronValidation.java +++ b/spring-xd-rest-domain/src/main/java/org/springframework/xd/rest/domain/validation/CronValidation.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rest-domain/src/test/java/org/springframework/xd/rest/client/domain/StepExecutionInfoResourceSerializationTests.java b/spring-xd-rest-domain/src/test/java/org/springframework/xd/rest/client/domain/StepExecutionInfoResourceSerializationTests.java index 611a2bf01..14ab968c8 100644 --- a/spring-xd-rest-domain/src/test/java/org/springframework/xd/rest/client/domain/StepExecutionInfoResourceSerializationTests.java +++ b/spring-xd-rest-domain/src/test/java/org/springframework/xd/rest/client/domain/StepExecutionInfoResourceSerializationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rxjava/src/main/java/org/springframework/xd/rxjava/MultipleSubjectMessageHandler.java b/spring-xd-rxjava/src/main/java/org/springframework/xd/rxjava/MultipleSubjectMessageHandler.java index 721b0c83a..19bea04af 100644 --- a/spring-xd-rxjava/src/main/java/org/springframework/xd/rxjava/MultipleSubjectMessageHandler.java +++ b/spring-xd-rxjava/src/main/java/org/springframework/xd/rxjava/MultipleSubjectMessageHandler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rxjava/src/main/java/org/springframework/xd/rxjava/Processor.java b/spring-xd-rxjava/src/main/java/org/springframework/xd/rxjava/Processor.java index 5bdc1b71b..8e3c2d09d 100644 --- a/spring-xd-rxjava/src/main/java/org/springframework/xd/rxjava/Processor.java +++ b/spring-xd-rxjava/src/main/java/org/springframework/xd/rxjava/Processor.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rxjava/src/main/java/org/springframework/xd/rxjava/SubjectMessageHandler.java b/spring-xd-rxjava/src/main/java/org/springframework/xd/rxjava/SubjectMessageHandler.java index b1295e914..13c2491f0 100644 --- a/spring-xd-rxjava/src/main/java/org/springframework/xd/rxjava/SubjectMessageHandler.java +++ b/spring-xd-rxjava/src/main/java/org/springframework/xd/rxjava/SubjectMessageHandler.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rxjava/src/test/java/org/springframework/xd/rxjava/AbstractMessageHandlerTests.java b/spring-xd-rxjava/src/test/java/org/springframework/xd/rxjava/AbstractMessageHandlerTests.java index 07a6e97e1..5c98873d6 100644 --- a/spring-xd-rxjava/src/test/java/org/springframework/xd/rxjava/AbstractMessageHandlerTests.java +++ b/spring-xd-rxjava/src/test/java/org/springframework/xd/rxjava/AbstractMessageHandlerTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rxjava/src/test/java/org/springframework/xd/rxjava/MultipleSubjectMessageHandlerTests.java b/spring-xd-rxjava/src/test/java/org/springframework/xd/rxjava/MultipleSubjectMessageHandlerTests.java index 8ca4aed4a..7d20921c0 100644 --- a/spring-xd-rxjava/src/test/java/org/springframework/xd/rxjava/MultipleSubjectMessageHandlerTests.java +++ b/spring-xd-rxjava/src/test/java/org/springframework/xd/rxjava/MultipleSubjectMessageHandlerTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rxjava/src/test/java/org/springframework/xd/rxjava/PongMessageProcessor.java b/spring-xd-rxjava/src/test/java/org/springframework/xd/rxjava/PongMessageProcessor.java index f5492d152..3551a2408 100644 --- a/spring-xd-rxjava/src/test/java/org/springframework/xd/rxjava/PongMessageProcessor.java +++ b/spring-xd-rxjava/src/test/java/org/springframework/xd/rxjava/PongMessageProcessor.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rxjava/src/test/java/org/springframework/xd/rxjava/PongStringProcessor.java b/spring-xd-rxjava/src/test/java/org/springframework/xd/rxjava/PongStringProcessor.java index e13a7936f..3d4975c3f 100644 --- a/spring-xd-rxjava/src/test/java/org/springframework/xd/rxjava/PongStringProcessor.java +++ b/spring-xd-rxjava/src/test/java/org/springframework/xd/rxjava/PongStringProcessor.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-rxjava/src/test/java/org/springframework/xd/rxjava/SubjectMessageHandlerTests.java b/spring-xd-rxjava/src/test/java/org/springframework/xd/rxjava/SubjectMessageHandlerTests.java index 827b22f1a..4f5c02fc8 100644 --- a/spring-xd-rxjava/src/test/java/org/springframework/xd/rxjava/SubjectMessageHandlerTests.java +++ b/spring-xd-rxjava/src/test/java/org/springframework/xd/rxjava/SubjectMessageHandlerTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/Configuration.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/Configuration.java index 92181c134..bc265054b 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/Configuration.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/Configuration.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/Target.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/Target.java index 8ac299c33..8e0bc90de 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/Target.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/Target.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/XDShell.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/XDShell.java index f5e195476..d90965350 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/XDShell.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/XDShell.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/XDShellBannerProvider.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/XDShellBannerProvider.java index 24ca063b9..67eda668b 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/XDShellBannerProvider.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/XDShellBannerProvider.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/XDShellPromptProvider.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/XDShellPromptProvider.java index 41efa8617..17207b304 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/XDShellPromptProvider.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/XDShellPromptProvider.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/AbstractMetricsCommands.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/AbstractMetricsCommands.java index 3ee195884..2203bf067 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/AbstractMetricsCommands.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/AbstractMetricsCommands.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/AggregateCounterCommands.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/AggregateCounterCommands.java index 3ca4e26a0..162e4351a 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/AggregateCounterCommands.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/AggregateCounterCommands.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/ConfigCommands.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/ConfigCommands.java index e71b41fcc..4149ad5b9 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/ConfigCommands.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/ConfigCommands.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/ConsoleUserInput.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/ConsoleUserInput.java index a8f723b33..e3b729cd7 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/ConsoleUserInput.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/ConsoleUserInput.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/CounterCommands.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/CounterCommands.java index b5e2403a0..5a4e33a73 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/CounterCommands.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/CounterCommands.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/DeploymentOptionKeys.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/DeploymentOptionKeys.java index b1516e395..99268911d 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/DeploymentOptionKeys.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/DeploymentOptionKeys.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/FieldValueCounterCommands.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/FieldValueCounterCommands.java index 94a54ae60..24feba35c 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/FieldValueCounterCommands.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/FieldValueCounterCommands.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/GaugeCommands.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/GaugeCommands.java index 77bd848c7..91ee40835 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/GaugeCommands.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/GaugeCommands.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/HttpCommands.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/HttpCommands.java index f39a433dd..71aa71e79 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/HttpCommands.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/HttpCommands.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/JobCommands.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/JobCommands.java index 1c5401abd..c6ae6081b 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/JobCommands.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/JobCommands.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/ModuleCommands.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/ModuleCommands.java index 2d8d6888b..196d12123 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/ModuleCommands.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/ModuleCommands.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/ModuleList.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/ModuleList.java index 766a3437a..cf5775452 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/ModuleList.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/ModuleList.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/RichGaugeCommands.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/RichGaugeCommands.java index c817389dc..cfbb9a076 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/RichGaugeCommands.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/RichGaugeCommands.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/RuntimeCommands.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/RuntimeCommands.java index e94c2229d..a9bbefdcb 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/RuntimeCommands.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/RuntimeCommands.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/StreamCommands.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/StreamCommands.java index 677db5da8..c9c73eccb 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/StreamCommands.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/StreamCommands.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/UserInput.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/UserInput.java index 2f6504ade..5913fbd90 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/UserInput.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/UserInput.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/support/JobCommandsUtils.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/support/JobCommandsUtils.java index 4d36e189b..3fa32bdb5 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/support/JobCommandsUtils.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/command/support/JobCommandsUtils.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/converter/CompletionConverter.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/converter/CompletionConverter.java index 36cc272ff..e6a6300ec 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/converter/CompletionConverter.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/converter/CompletionConverter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/converter/ExistingXDEntityConverter.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/converter/ExistingXDEntityConverter.java index bda31fccf..7396d2a3e 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/converter/ExistingXDEntityConverter.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/converter/ExistingXDEntityConverter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/converter/MediaTypeConverter.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/converter/MediaTypeConverter.java index c0577efd7..3277c6096 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/converter/MediaTypeConverter.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/converter/MediaTypeConverter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/converter/NumberFormatConverter.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/converter/NumberFormatConverter.java index 5b81de073..31f8c0656 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/converter/NumberFormatConverter.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/converter/NumberFormatConverter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/converter/QualifiedModuleNameConverter.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/converter/QualifiedModuleNameConverter.java index 8c6977dfc..e01b3849f 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/converter/QualifiedModuleNameConverter.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/converter/QualifiedModuleNameConverter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/hadoop/ConfigurationAware.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/hadoop/ConfigurationAware.java index 8463c922e..2dc3abd92 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/hadoop/ConfigurationAware.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/hadoop/ConfigurationAware.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/hadoop/ConfigurationCommands.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/hadoop/ConfigurationCommands.java index c52797e16..813adf54d 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/hadoop/ConfigurationCommands.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/hadoop/ConfigurationCommands.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/hadoop/ConfigurationModifiedEvent.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/hadoop/ConfigurationModifiedEvent.java index cdc871ed3..39ee05f1a 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/hadoop/ConfigurationModifiedEvent.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/hadoop/ConfigurationModifiedEvent.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/hadoop/FsShellCommands.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/hadoop/FsShellCommands.java index 90c553501..ed6a06e9a 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/hadoop/FsShellCommands.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/hadoop/FsShellCommands.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/util/Assertions.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/util/Assertions.java index f5bf051c5..811ef50a7 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/util/Assertions.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/util/Assertions.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/util/CommonUtils.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/util/CommonUtils.java index 2a40ca017..66bb33a04 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/util/CommonUtils.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/util/CommonUtils.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/util/JsonUtil.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/util/JsonUtil.java index 9c70f5216..580153a3c 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/util/JsonUtil.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/util/JsonUtil.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/util/Table.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/util/Table.java index 97f9859bd..e945abc49 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/util/Table.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/util/Table.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/util/TableHeader.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/util/TableHeader.java index cac7e1971..bf2b7b283 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/util/TableHeader.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/util/TableHeader.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/util/TableRow.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/util/TableRow.java index 33d872389..4c087a069 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/util/TableRow.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/util/TableRow.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/main/java/org/springframework/xd/shell/util/UiUtils.java b/spring-xd-shell/src/main/java/org/springframework/xd/shell/util/UiUtils.java index eda4fa952..fdc8b2e53 100644 --- a/spring-xd-shell/src/main/java/org/springframework/xd/shell/util/UiUtils.java +++ b/spring-xd-shell/src/main/java/org/springframework/xd/shell/util/UiUtils.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/AbstractShellIntegrationTest.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/AbstractShellIntegrationTest.java index 072db6922..df152df82 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/AbstractShellIntegrationTest.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/AbstractShellIntegrationTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/ModuleTypeTest.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/ModuleTypeTest.java index 1b9a8b365..4e7cf4a71 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/ModuleTypeTest.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/ModuleTypeTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/bus/RabbitBusCleanerIntegrationTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/bus/RabbitBusCleanerIntegrationTests.java index bcabbca93..dea2565eb 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/bus/RabbitBusCleanerIntegrationTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/bus/RabbitBusCleanerIntegrationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractCommandTemplate.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractCommandTemplate.java index 89e0c59d6..1506c443a 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractCommandTemplate.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractCommandTemplate.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractFileSourceAndFileSinkTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractFileSourceAndFileSinkTests.java index ca68e3d0a..5e7fd627d 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractFileSourceAndFileSinkTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractFileSourceAndFileSinkTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractFtpModulesTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractFtpModulesTests.java index bdee2fb6f..f9bde2673 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractFtpModulesTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractFtpModulesTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractHttpCommandsTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractHttpCommandsTests.java index 54b3ad854..a3b325d6a 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractHttpCommandsTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractHttpCommandsTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractJarDeletingModuleCommandsTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractJarDeletingModuleCommandsTests.java index 605cb9564..a403cae8c 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractJarDeletingModuleCommandsTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractJarDeletingModuleCommandsTests.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractJdbcModulesTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractJdbcModulesTests.java index e01841af4..56549f7df 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractJdbcModulesTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractJdbcModulesTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractJobCommandsTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractJobCommandsTests.java index 9ca9065c4..0a191e176 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractJobCommandsTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractJobCommandsTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractJobCommandsWithHadoopTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractJobCommandsWithHadoopTests.java index 8d16edd82..ca204cff4 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractJobCommandsWithHadoopTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractJobCommandsWithHadoopTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractJobIntegrationTest.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractJobIntegrationTest.java index e6ec2393a..53f5e23d4 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractJobIntegrationTest.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractJobIntegrationTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractKafkaSourceSinkTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractKafkaSourceSinkTests.java index b0fc8b5c3..1a77a8d95 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractKafkaSourceSinkTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractKafkaSourceSinkTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractMailCommandsTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractMailCommandsTests.java index 46b836657..b8222f0bd 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractMailCommandsTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractMailCommandsTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractMetricsTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractMetricsTests.java index 2ac8b2df2..572b6ebcb 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractMetricsTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractMetricsTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractModuleClasspathTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractModuleClasspathTests.java index 284aabe7d..b6b064896 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractModuleClasspathTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractModuleClasspathTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractModuleCommandsTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractModuleCommandsTests.java index cbb2e085a..b294a69bb 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractModuleCommandsTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractModuleCommandsTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractNamedChannelTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractNamedChannelTests.java index 435e4fc03..7bebc4284 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractNamedChannelTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractNamedChannelTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractProcessorsTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractProcessorsTests.java index cd4611ae5..b2fa039e9 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractProcessorsTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractProcessorsTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractRabbitSourceAndRabbitSinkTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractRabbitSourceAndRabbitSinkTests.java index c42b6c892..346f614ae 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractRabbitSourceAndRabbitSinkTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractRabbitSourceAndRabbitSinkTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractRedisSinkTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractRedisSinkTests.java index d253b867f..0b9562325 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractRedisSinkTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractRedisSinkTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractRouterSinkTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractRouterSinkTests.java index bb14674b5..89e112307 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractRouterSinkTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractRouterSinkTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractRuntimeCommandsTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractRuntimeCommandsTests.java index c24ec4d7d..cef70d651 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractRuntimeCommandsTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractRuntimeCommandsTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractSftpSourceTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractSftpSourceTests.java index 5539d88d1..56b54d2f2 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractSftpSourceTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractSftpSourceTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractSpelPropertyAccessorIntegrationTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractSpelPropertyAccessorIntegrationTests.java index e65397dc3..8d06b4448 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractSpelPropertyAccessorIntegrationTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractSpelPropertyAccessorIntegrationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractStreamCommandsTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractStreamCommandsTests.java index 53db8d4c5..d058fa77d 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractStreamCommandsTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractStreamCommandsTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractStreamIntegrationTest.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractStreamIntegrationTest.java index a9438072f..0da8b0a1e 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractStreamIntegrationTest.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractStreamIntegrationTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractTcpModulesTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractTcpModulesTests.java index a031d944e..0249721ec 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractTcpModulesTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractTcpModulesTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractTriggerModulesTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractTriggerModulesTests.java index b294e5de6..7af7f4490 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractTriggerModulesTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/AbstractTriggerModulesTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/MessageStoreBenchmarkTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/MessageStoreBenchmarkTests.java index 30750fffe..74a99a714 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/MessageStoreBenchmarkTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/MessageStoreBenchmarkTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/MetricsTemplate.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/MetricsTemplate.java index 4905c3f26..8a7041c70 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/MetricsTemplate.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/MetricsTemplate.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/ModuleListTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/ModuleListTests.java index f53e9e848..25e79e9f6 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/ModuleListTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/ModuleListTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/ModuleTemplate.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/ModuleTemplate.java index 0847c4ea5..e17dbc122 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/ModuleTemplate.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/ModuleTemplate.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/MySuite.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/MySuite.java index 14e216501..bf7c6905a 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/MySuite.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/MySuite.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/SimpleTasklet.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/SimpleTasklet.java index ea8ca9094..0f6bf2dc1 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/SimpleTasklet.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/SimpleTasklet.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/SimpleTwoPartitionsPartitioner.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/SimpleTwoPartitionsPartitioner.java index e6531f0db..b82fa7456 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/SimpleTwoPartitionsPartitioner.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/SimpleTwoPartitionsPartitioner.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/SpringBatchStepExecutionTestTasklet.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/SpringBatchStepExecutionTestTasklet.java index 350114822..dbe4369ca 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/SpringBatchStepExecutionTestTasklet.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/SpringBatchStepExecutionTestTasklet.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/SpringBatchWithParametersTasklet.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/SpringBatchWithParametersTasklet.java index a7edd7681..49c41446a 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/SpringBatchWithParametersTasklet.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/SpringBatchWithParametersTasklet.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/StreamCommandsTemplate.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/StreamCommandsTemplate.java index 45ee9f339..5447c2511 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/StreamCommandsTemplate.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/StreamCommandsTemplate.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/StreamCommandsUnitTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/StreamCommandsUnitTests.java index 1fcb40964..65d8bdd6f 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/StreamCommandsUnitTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/StreamCommandsUnitTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/fixtures/FieldValueCounterSink.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/fixtures/FieldValueCounterSink.java index aecddd51f..d0ac19354 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/fixtures/FieldValueCounterSink.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/fixtures/FieldValueCounterSink.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/fixtures/HttpSource.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/fixtures/HttpSource.java index 1da008bc1..43eefa7ec 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/fixtures/HttpSource.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/fixtures/HttpSource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/fixtures/MetricExistsMatcher.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/fixtures/MetricExistsMatcher.java index 0cac2e04f..b7a8d7047 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/fixtures/MetricExistsMatcher.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/fixtures/MetricExistsMatcher.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/fixtures/RichGaugeSink.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/fixtures/RichGaugeSink.java index d4690b9ea..36b7a8a03 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/fixtures/RichGaugeSink.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/fixtures/RichGaugeSink.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/fixtures/XDMatchers.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/fixtures/XDMatchers.java index d322db674..f21be8414 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/fixtures/XDMatchers.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/fixtures/XDMatchers.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/fixtures/package-info.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/fixtures/package-info.java index d18dc576d..822221130 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/fixtures/package-info.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/fixtures/package-info.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/FileSourceAndFileSinkTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/FileSourceAndFileSinkTests.java index 6c086947b..ededf19a6 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/FileSourceAndFileSinkTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/FileSourceAndFileSinkTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/FtpModulesTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/FtpModulesTests.java index d92dc14ea..3b9188e20 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/FtpModulesTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/FtpModulesTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/HttpCommandsTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/HttpCommandsTests.java index 18f744c10..a2c2aadc4 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/HttpCommandsTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/HttpCommandsTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/JarDeletingModuleCommandsTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/JarDeletingModuleCommandsTests.java index 6303a6123..f7c9ca805 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/JarDeletingModuleCommandsTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/JarDeletingModuleCommandsTests.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/JdbcModulesTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/JdbcModulesTests.java index 99e5b74d1..99956155b 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/JdbcModulesTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/JdbcModulesTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/JobCommandsTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/JobCommandsTests.java index fe55b6f79..f9147cde4 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/JobCommandsTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/JobCommandsTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/JobCommandsWithHadoopTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/JobCommandsWithHadoopTests.java index b5a8f48b1..12da225a8 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/JobCommandsWithHadoopTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/JobCommandsWithHadoopTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/KafkaSourceSinkTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/KafkaSourceSinkTests.java index 29dc0fd0c..075a3d775 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/KafkaSourceSinkTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/KafkaSourceSinkTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/MailCommandsTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/MailCommandsTests.java index a188d4211..5b2679366 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/MailCommandsTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/MailCommandsTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/MetricsTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/MetricsTests.java index c0849c6d5..00585daa3 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/MetricsTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/MetricsTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/ModuleClasspathTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/ModuleClasspathTests.java index 9cfbec1e2..033133702 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/ModuleClasspathTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/ModuleClasspathTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/ModuleCommandsTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/ModuleCommandsTests.java index 9564d53e1..91ac9d7d1 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/ModuleCommandsTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/ModuleCommandsTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/NamedChannelTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/NamedChannelTests.java index 9998bde90..d26e1967f 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/NamedChannelTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/NamedChannelTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/ProcessorsTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/ProcessorsTests.java index a42b4361d..ee0e41689 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/ProcessorsTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/ProcessorsTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/RabbitSourceAndRabbitSinkTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/RabbitSourceAndRabbitSinkTests.java index 419660f01..d3515ec7c 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/RabbitSourceAndRabbitSinkTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/RabbitSourceAndRabbitSinkTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/RedisSinkTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/RedisSinkTests.java index 98562c92f..b7b6e3948 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/RedisSinkTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/RedisSinkTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/RouterSinkTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/RouterSinkTests.java index fd895d21b..5d9ec027e 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/RouterSinkTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/RouterSinkTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/RuntimeCommandsTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/RuntimeCommandsTests.java index 888927d2b..95676e783 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/RuntimeCommandsTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/RuntimeCommandsTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/SftpSourceTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/SftpSourceTests.java index 487780b69..34069af6e 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/SftpSourceTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/SftpSourceTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/ShellCommandsTestSuite.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/ShellCommandsTestSuite.java index 2a811e888..94beaea88 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/ShellCommandsTestSuite.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/ShellCommandsTestSuite.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/SpelPropertyAccessorIntegrationTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/SpelPropertyAccessorIntegrationTests.java index 7bc38b508..7ac678125 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/SpelPropertyAccessorIntegrationTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/SpelPropertyAccessorIntegrationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/StreamCommandsTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/StreamCommandsTests.java index b097bb006..d2b44cbe2 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/StreamCommandsTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/StreamCommandsTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/TcpModulesTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/TcpModulesTests.java index 49a3f8acf..4b1801322 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/TcpModulesTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/TcpModulesTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/TriggerModulesTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/TriggerModulesTests.java index 7c32c9a76..61c59a1ea 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/TriggerModulesTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/nosecurity/TriggerModulesTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/FileSourceAndFileSinkWithSecurityTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/FileSourceAndFileSinkWithSecurityTests.java index 99a220ff8..52e17f006 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/FileSourceAndFileSinkWithSecurityTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/FileSourceAndFileSinkWithSecurityTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/FtpModulesWithSecurityTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/FtpModulesWithSecurityTests.java index 284e5a351..31de3c1ce 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/FtpModulesWithSecurityTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/FtpModulesWithSecurityTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/HttpCommandsWithSecurityTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/HttpCommandsWithSecurityTests.java index b2812ce7e..17af4cf7d 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/HttpCommandsWithSecurityTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/HttpCommandsWithSecurityTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/JarDeletingModuleCommandsWithSecurityTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/JarDeletingModuleCommandsWithSecurityTests.java index c3ecacb1a..fba5c8c7a 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/JarDeletingModuleCommandsWithSecurityTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/JarDeletingModuleCommandsWithSecurityTests.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/JdbcModulesWithSecurityTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/JdbcModulesWithSecurityTests.java index 29d6b2098..731b1b3a6 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/JdbcModulesWithSecurityTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/JdbcModulesWithSecurityTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/JobCommandsWithHadoopAndSecurityTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/JobCommandsWithHadoopAndSecurityTests.java index f29461654..200939cd5 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/JobCommandsWithHadoopAndSecurityTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/JobCommandsWithHadoopAndSecurityTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/JobCommandsWithSecurityTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/JobCommandsWithSecurityTests.java index 2b35d4394..732819608 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/JobCommandsWithSecurityTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/JobCommandsWithSecurityTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/KafkaSourceSinkWithSecurityTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/KafkaSourceSinkWithSecurityTests.java index 46a0eaa12..b4c1ceed7 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/KafkaSourceSinkWithSecurityTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/KafkaSourceSinkWithSecurityTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/MailCommandsWithSecurityTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/MailCommandsWithSecurityTests.java index a773c2b42..ed9e13fb1 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/MailCommandsWithSecurityTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/MailCommandsWithSecurityTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/MetricsWithSecurityTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/MetricsWithSecurityTests.java index a9503d7ed..958562c7b 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/MetricsWithSecurityTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/MetricsWithSecurityTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/ModuleClasspathWithSecurityTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/ModuleClasspathWithSecurityTests.java index 64425bb38..4111cf0a7 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/ModuleClasspathWithSecurityTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/ModuleClasspathWithSecurityTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/ModuleCommandsWithSecurityTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/ModuleCommandsWithSecurityTests.java index 53cc3813c..400e7e79c 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/ModuleCommandsWithSecurityTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/ModuleCommandsWithSecurityTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/NamedChannelWithSecurityTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/NamedChannelWithSecurityTests.java index 7b72b06ad..a65c1ac06 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/NamedChannelWithSecurityTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/NamedChannelWithSecurityTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/ProcessorsWithSecurityTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/ProcessorsWithSecurityTests.java index 857ed98f1..12f59188f 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/ProcessorsWithSecurityTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/ProcessorsWithSecurityTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/RabbitSourceAndRabbitSinkWithSecurityTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/RabbitSourceAndRabbitSinkWithSecurityTests.java index b7ce83cfa..0361529a9 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/RabbitSourceAndRabbitSinkWithSecurityTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/RabbitSourceAndRabbitSinkWithSecurityTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/RedisSinkWithSecurityTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/RedisSinkWithSecurityTests.java index a52b47345..664973660 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/RedisSinkWithSecurityTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/RedisSinkWithSecurityTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/RouterSinkWithSecurityTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/RouterSinkWithSecurityTests.java index cbcdc4b06..8be175825 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/RouterSinkWithSecurityTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/RouterSinkWithSecurityTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/RuntimeCommandsWithSecurityTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/RuntimeCommandsWithSecurityTests.java index 6cc1d4911..4e0867f56 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/RuntimeCommandsWithSecurityTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/RuntimeCommandsWithSecurityTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/SftpSourceWithSecurityTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/SftpSourceWithSecurityTests.java index db60c1180..9fd73edac 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/SftpSourceWithSecurityTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/SftpSourceWithSecurityTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/ShellCommandsWithSecurityTestSuite.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/ShellCommandsWithSecurityTestSuite.java index 4895ed75a..0b4dfdce2 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/ShellCommandsWithSecurityTestSuite.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/ShellCommandsWithSecurityTestSuite.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/SpelPropertyAccessorIntegrationWithSecurityTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/SpelPropertyAccessorIntegrationWithSecurityTests.java index 2ca01da51..8bee3dc83 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/SpelPropertyAccessorIntegrationWithSecurityTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/SpelPropertyAccessorIntegrationWithSecurityTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/StreamCommandsWithSecurityTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/StreamCommandsWithSecurityTests.java index 6d12aa68b..05de0df60 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/StreamCommandsWithSecurityTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/StreamCommandsWithSecurityTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/TcpModulesWithSecurityTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/TcpModulesWithSecurityTests.java index 3cf29847e..3ec06d5fd 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/TcpModulesWithSecurityTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/TcpModulesWithSecurityTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/TriggerModulesWithSecurityTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/TriggerModulesWithSecurityTests.java index aabd1a496..88e633f9b 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/TriggerModulesWithSecurityTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/security/TriggerModulesWithSecurityTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/support/JobCommandsUtilsTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/support/JobCommandsUtilsTests.java index 9c5a71e5c..d7a4abfd6 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/support/JobCommandsUtilsTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/command/support/JobCommandsUtilsTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/security/SecuredShellAccessTestSuite.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/security/SecuredShellAccessTestSuite.java index 88decb426..0fceed0d4 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/security/SecuredShellAccessTestSuite.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/security/SecuredShellAccessTestSuite.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/security/SecuredShellAccessTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/security/SecuredShellAccessTests.java index 723a0a1df..4f6a7ccca 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/security/SecuredShellAccessTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/security/SecuredShellAccessTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/security/SecuredShellAccessWithSslTests.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/security/SecuredShellAccessWithSslTests.java index c581f0562..c564bad5f 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/security/SecuredShellAccessWithSslTests.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/security/SecuredShellAccessWithSslTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/util/CliAvailabilityIndicatorChecker.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/util/CliAvailabilityIndicatorChecker.java index e080680dc..b3d56f26d 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/util/CliAvailabilityIndicatorChecker.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/util/CliAvailabilityIndicatorChecker.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/util/CommonUtilsTest.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/util/CommonUtilsTest.java index 8eb26f9d2..51c4255a3 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/util/CommonUtilsTest.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/util/CommonUtilsTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/util/TableMatchers.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/util/TableMatchers.java index 62b71ef3d..75aa34b12 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/util/TableMatchers.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/util/TableMatchers.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/util/TestFtpServer.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/util/TestFtpServer.java index 553428152..f484ac5fd 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/util/TestFtpServer.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/util/TestFtpServer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/util/TestSftpServer.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/util/TestSftpServer.java index 8966e9a42..3cc08474a 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/util/TestSftpServer.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/util/TestSftpServer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-shell/src/test/java/org/springframework/xd/shell/util/UiUtilsTest.java b/spring-xd-shell/src/test/java/org/springframework/xd/shell/util/UiUtilsTest.java index 81d7f109c..81482ea67 100644 --- a/spring-xd-shell/src/test/java/org/springframework/xd/shell/util/UiUtilsTest.java +++ b/spring-xd-shell/src/test/java/org/springframework/xd/shell/util/UiUtilsTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-spark-streaming-tests/src/test/java/org/springframework/xd/spark/streaming/AbstractSparkStreamingTests.java b/spring-xd-spark-streaming-tests/src/test/java/org/springframework/xd/spark/streaming/AbstractSparkStreamingTests.java index 606a2245b..3143f468f 100644 --- a/spring-xd-spark-streaming-tests/src/test/java/org/springframework/xd/spark/streaming/AbstractSparkStreamingTests.java +++ b/spring-xd-spark-streaming-tests/src/test/java/org/springframework/xd/spark/streaming/AbstractSparkStreamingTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-spark-streaming-tests/src/test/java/org/springframework/xd/spark/streaming/KafkaTransportSparkStreamingTests.java b/spring-xd-spark-streaming-tests/src/test/java/org/springframework/xd/spark/streaming/KafkaTransportSparkStreamingTests.java index 549587015..6a823fb2b 100644 --- a/spring-xd-spark-streaming-tests/src/test/java/org/springframework/xd/spark/streaming/KafkaTransportSparkStreamingTests.java +++ b/spring-xd-spark-streaming-tests/src/test/java/org/springframework/xd/spark/streaming/KafkaTransportSparkStreamingTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-spark-streaming-tests/src/test/java/org/springframework/xd/spark/streaming/LocalTransportSparkStreamingTests.java b/spring-xd-spark-streaming-tests/src/test/java/org/springframework/xd/spark/streaming/LocalTransportSparkStreamingTests.java index 65475d1d5..a3103cfcf 100644 --- a/spring-xd-spark-streaming-tests/src/test/java/org/springframework/xd/spark/streaming/LocalTransportSparkStreamingTests.java +++ b/spring-xd-spark-streaming-tests/src/test/java/org/springframework/xd/spark/streaming/LocalTransportSparkStreamingTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-spark-streaming-tests/src/test/java/org/springframework/xd/spark/streaming/RabbitTransportSparkStreamingTests.java b/spring-xd-spark-streaming-tests/src/test/java/org/springframework/xd/spark/streaming/RabbitTransportSparkStreamingTests.java index d46c52c2c..dae727e93 100644 --- a/spring-xd-spark-streaming-tests/src/test/java/org/springframework/xd/spark/streaming/RabbitTransportSparkStreamingTests.java +++ b/spring-xd-spark-streaming-tests/src/test/java/org/springframework/xd/spark/streaming/RabbitTransportSparkStreamingTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-spark-streaming-tests/src/test/java/org/springframework/xd/spark/streaming/RedisTransportSparkStreamingTests.java b/spring-xd-spark-streaming-tests/src/test/java/org/springframework/xd/spark/streaming/RedisTransportSparkStreamingTests.java index 95730bf47..15a5de0b2 100644 --- a/spring-xd-spark-streaming-tests/src/test/java/org/springframework/xd/spark/streaming/RedisTransportSparkStreamingTests.java +++ b/spring-xd-spark-streaming-tests/src/test/java/org/springframework/xd/spark/streaming/RedisTransportSparkStreamingTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/DefaultSparkStreamingModuleOptionsMetadata.java b/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/DefaultSparkStreamingModuleOptionsMetadata.java index 0af707b3a..bd2fe023b 100644 --- a/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/DefaultSparkStreamingModuleOptionsMetadata.java +++ b/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/DefaultSparkStreamingModuleOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/SparkConfig.java b/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/SparkConfig.java index c9195aee9..a29734536 100644 --- a/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/SparkConfig.java +++ b/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/SparkConfig.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/SparkMessageSender.java b/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/SparkMessageSender.java index 2a08c8f29..d13feea6e 100644 --- a/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/SparkMessageSender.java +++ b/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/SparkMessageSender.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/SparkStreamingModuleExecutor.java b/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/SparkStreamingModuleExecutor.java index 8f90a7fca..a2c70dd44 100644 --- a/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/SparkStreamingModuleExecutor.java +++ b/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/SparkStreamingModuleExecutor.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/SparkStreamingSupport.java b/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/SparkStreamingSupport.java index b7434bf27..2643e25b6 100644 --- a/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/SparkStreamingSupport.java +++ b/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/SparkStreamingSupport.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/examples/java/FileLogger.java b/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/examples/java/FileLogger.java index 317ae2bb3..b2e551ec7 100644 --- a/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/examples/java/FileLogger.java +++ b/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/examples/java/FileLogger.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/examples/java/FileLoggerModuleOptionsMetadata.java b/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/examples/java/FileLoggerModuleOptionsMetadata.java index 097084495..41aae8ea8 100644 --- a/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/examples/java/FileLoggerModuleOptionsMetadata.java +++ b/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/examples/java/FileLoggerModuleOptionsMetadata.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/examples/java/WordCount.java b/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/examples/java/WordCount.java index 468286dd4..7a9e9afd8 100644 --- a/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/examples/java/WordCount.java +++ b/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/examples/java/WordCount.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/java/ModuleExecutor.java b/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/java/ModuleExecutor.java index aa4864332..ea3d9eb69 100644 --- a/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/java/ModuleExecutor.java +++ b/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/java/ModuleExecutor.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/java/Processor.java b/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/java/Processor.java index d7fb2423e..225488814 100644 --- a/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/java/Processor.java +++ b/spring-xd-spark-streaming/src/main/java/org/springframework/xd/spark/streaming/java/Processor.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-spark-streaming/src/main/scala/org/springframework/xd/spark/streaming/examples/scala/FileLogger.scala b/spring-xd-spark-streaming/src/main/scala/org/springframework/xd/spark/streaming/examples/scala/FileLogger.scala index 2147e0f74..a13aad425 100644 --- a/spring-xd-spark-streaming/src/main/scala/org/springframework/xd/spark/streaming/examples/scala/FileLogger.scala +++ b/spring-xd-spark-streaming/src/main/scala/org/springframework/xd/spark/streaming/examples/scala/FileLogger.scala @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-spark-streaming/src/main/scala/org/springframework/xd/spark/streaming/examples/scala/WordCount.scala b/spring-xd-spark-streaming/src/main/scala/org/springframework/xd/spark/streaming/examples/scala/WordCount.scala index 8fdd16a4b..87f6bf077 100644 --- a/spring-xd-spark-streaming/src/main/scala/org/springframework/xd/spark/streaming/examples/scala/WordCount.scala +++ b/spring-xd-spark-streaming/src/main/scala/org/springframework/xd/spark/streaming/examples/scala/WordCount.scala @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-spark-streaming/src/main/scala/org/springframework/xd/spark/streaming/scala/ModuleExecutor.scala b/spring-xd-spark-streaming/src/main/scala/org/springframework/xd/spark/streaming/scala/ModuleExecutor.scala index c2c184b26..6b34407ed 100644 --- a/spring-xd-spark-streaming/src/main/scala/org/springframework/xd/spark/streaming/scala/ModuleExecutor.scala +++ b/spring-xd-spark-streaming/src/main/scala/org/springframework/xd/spark/streaming/scala/ModuleExecutor.scala @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-spark-streaming/src/main/scala/org/springframework/xd/spark/streaming/scala/Processor.scala b/spring-xd-spark-streaming/src/main/scala/org/springframework/xd/spark/streaming/scala/Processor.scala index 5bd833b5a..f06255ee1 100644 --- a/spring-xd-spark-streaming/src/main/scala/org/springframework/xd/spark/streaming/scala/Processor.scala +++ b/spring-xd-spark-streaming/src/main/scala/org/springframework/xd/spark/streaming/scala/Processor.scala @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/AbstractMailSource.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/AbstractMailSource.java index c9074d732..ea99dd4dd 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/AbstractMailSource.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/AbstractMailSource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/AbstractMetricSink.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/AbstractMetricSink.java index 638df1615..179008b33 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/AbstractMetricSink.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/AbstractMetricSink.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/AbstractModuleFixture.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/AbstractModuleFixture.java index f0dc9e729..fd0e4f53f 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/AbstractModuleFixture.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/AbstractModuleFixture.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/AggregateCounterSink.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/AggregateCounterSink.java index 390a5a803..68fc37678 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/AggregateCounterSink.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/AggregateCounterSink.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/CounterSink.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/CounterSink.java index e65bf8221..fb8ad7e85 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/CounterSink.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/CounterSink.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/Disposable.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/Disposable.java index c85df5929..d952edc78 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/Disposable.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/Disposable.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/DisposableFileSupport.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/DisposableFileSupport.java index 06072ad6c..7cd9d7e82 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/DisposableFileSupport.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/DisposableFileSupport.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/DisposableMailSupport.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/DisposableMailSupport.java index e385be30b..60f6fba4a 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/DisposableMailSupport.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/DisposableMailSupport.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/EventuallyMatcher.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/EventuallyMatcher.java index 53e05c828..2ebb801ef 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/EventuallyMatcher.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/EventuallyMatcher.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FileJdbcJob.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FileJdbcJob.java index 7547f7834..35d8a93ed 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FileJdbcJob.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FileJdbcJob.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FilePollHdfsJob.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FilePollHdfsJob.java index c0a1d6c29..321591f8c 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FilePollHdfsJob.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FilePollHdfsJob.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, @@ -26,7 +26,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FileSink.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FileSink.java index 0bc53ce27..aa837b2e8 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FileSink.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FileSink.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FileSource.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FileSource.java index 682707b62..f73f06e3a 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FileSource.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FileSource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FtpDummyUserManager.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FtpDummyUserManager.java index 4dc5ae35b..7c79f9a46 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FtpDummyUserManager.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FtpDummyUserManager.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FtpHdfsJob.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FtpHdfsJob.java index 214a327e1..6a41e9b49 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FtpHdfsJob.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FtpHdfsJob.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, @@ -26,7 +26,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FtpSink.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FtpSink.java index 4c5ae8aa5..ec43ee221 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FtpSink.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FtpSink.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FtpSource.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FtpSource.java index 6c885fea3..b66a548c5 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FtpSource.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/FtpSource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/GemFireCQSource.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/GemFireCQSource.java index da98af9e1..31b9f1205 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/GemFireCQSource.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/GemFireCQSource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/GemFireServerSink.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/GemFireServerSink.java index 82874c93a..0a0346d9f 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/GemFireServerSink.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/GemFireServerSink.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/GemFireSource.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/GemFireSource.java index a5b22cb57..1af92e13f 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/GemFireSource.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/GemFireSource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/HasDisplayValue.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/HasDisplayValue.java index cad0b5bd6..c7d657db5 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/HasDisplayValue.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/HasDisplayValue.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/HdfsJdbcJob.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/HdfsJdbcJob.java index 2ac1d8e07..0afb7fd7c 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/HdfsJdbcJob.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/HdfsJdbcJob.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/HdfsMongoDbJob.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/HdfsMongoDbJob.java index 258de9ea3..0b1393b06 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/HdfsMongoDbJob.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/HdfsMongoDbJob.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/HdfsSink.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/HdfsSink.java index 649c60f1b..db99f8f4d 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/HdfsSink.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/HdfsSink.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/IncrementalJdbcHdfsJob.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/IncrementalJdbcHdfsJob.java index dd0d6e372..0337ca834 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/IncrementalJdbcHdfsJob.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/IncrementalJdbcHdfsJob.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/JdbcHdfsJob.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/JdbcHdfsJob.java index b93baaf02..75442f776 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/JdbcHdfsJob.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/JdbcHdfsJob.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/JdbcSink.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/JdbcSink.java index 30183905e..617df4a09 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/JdbcSink.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/JdbcSink.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/JdbcSource.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/JdbcSource.java index 293e968d9..35bb6321a 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/JdbcSource.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/JdbcSource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/JmsSource.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/JmsSource.java index 11217d057..fb2cdfb47 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/JmsSource.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/JmsSource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/KafkaSink.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/KafkaSink.java index eeb590c4c..c97336d14 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/KafkaSink.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/KafkaSink.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/KafkaSource.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/KafkaSource.java index 222c6eaba..b29811de8 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/KafkaSource.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/KafkaSource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/LogSink.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/LogSink.java index 08385abf1..a4ac17766 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/LogSink.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/LogSink.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/MailSink.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/MailSink.java index 4ec2c8ad5..a4a63b611 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/MailSink.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/MailSink.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/MetricHasSimpleValueMatcher.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/MetricHasSimpleValueMatcher.java index 8c8570753..52e3f6453 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/MetricHasSimpleValueMatcher.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/MetricHasSimpleValueMatcher.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/MqttSink.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/MqttSink.java index b3661dbff..36a4e5b7f 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/MqttSink.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/MqttSink.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/MqttSource.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/MqttSource.java index efc5eca56..e73731cd8 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/MqttSource.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/MqttSource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/NonPollingImapSource.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/NonPollingImapSource.java index 0b8776bd5..e3b7ec6f0 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/NonPollingImapSource.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/NonPollingImapSource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/PartitionedJdbcHdfsJob.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/PartitionedJdbcHdfsJob.java index f49ef8fdc..5e4151922 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/PartitionedJdbcHdfsJob.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/PartitionedJdbcHdfsJob.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/PollingMailSource.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/PollingMailSource.java index 2180f30d3..38aec02a3 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/PollingMailSource.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/PollingMailSource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/RabbitSink.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/RabbitSink.java index b8409c04c..fdbe95ea6 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/RabbitSink.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/RabbitSink.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/RabbitSource.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/RabbitSource.java index cdc17dec2..4a138f087 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/RabbitSource.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/RabbitSource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SimpleCounterSink.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SimpleCounterSink.java index 19e2cfce1..e5cf7f5bb 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SimpleCounterSink.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SimpleCounterSink.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SimpleFileSink.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SimpleFileSink.java index 408c6d8ff..440d3f189 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SimpleFileSink.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SimpleFileSink.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SimpleFileSource.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SimpleFileSource.java index a8fe9a0d8..b57e3d758 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SimpleFileSource.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SimpleFileSource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SimpleHttpSource.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SimpleHttpSource.java index db0863ccf..1c10fb7a9 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SimpleHttpSource.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SimpleHttpSource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SimpleTailSource.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SimpleTailSource.java index c3fbd574e..6b8c85bc3 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SimpleTailSource.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SimpleTailSource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SparkAppJob.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SparkAppJob.java index 1a5db7e99..34cefa7bd 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SparkAppJob.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SparkAppJob.java @@ -6,7 +6,7 @@ * * you may not use this file except in compliance with the License. * * You may obtain a copy of the License at * * - * * http://www.apache.org/licenses/LICENSE-2.0 + * * https://www.apache.org/licenses/LICENSE-2.0 * * * * Unless required by applicable law or agreed to in writing, software * * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SyslogTcpSource.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SyslogTcpSource.java index a4df55f10..715d923f7 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SyslogTcpSource.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SyslogTcpSource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SyslogUdpSource.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SyslogUdpSource.java index bfc068f42..5368b5439 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SyslogUdpSource.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/SyslogUdpSource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/TailSource.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/TailSource.java index fa4a9c4dd..a0f370a55 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/TailSource.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/TailSource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/Tap.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/Tap.java index 40f9e276b..54016190b 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/Tap.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/Tap.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/TcpClientSource.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/TcpClientSource.java index 523a54ae8..017549b63 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/TcpClientSource.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/TcpClientSource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/TcpSink.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/TcpSink.java index a3d0b4d6b..7c3eb363e 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/TcpSink.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/TcpSink.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/TcpSource.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/TcpSource.java index 0395b5661..619bca0a4 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/TcpSource.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/TcpSource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/Transform.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/Transform.java index aa3dd54c8..7cc01b415 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/Transform.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/Transform.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/TwitterSearchSource.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/TwitterSearchSource.java index b0c6bd42a..bcee97026 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/TwitterSearchSource.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/TwitterSearchSource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/TwitterStreamSource.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/TwitterStreamSource.java index d453c5e08..f24667e97 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/TwitterStreamSource.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/TwitterStreamSource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/util/AvailableSocketPorts.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/util/AvailableSocketPorts.java index 2fc750de2..c3a229589 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/util/AvailableSocketPorts.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/util/AvailableSocketPorts.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/util/FixtureUtils.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/util/FixtureUtils.java index 9335b1af8..6e2d47944 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/util/FixtureUtils.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/util/FixtureUtils.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/util/KafkaUtils.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/util/KafkaUtils.java index b82d42ea1..8f68a8445 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/util/KafkaUtils.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/fixtures/util/KafkaUtils.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/generator/GeneratorException.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/generator/GeneratorException.java index 1559bb8bd..c94716acb 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/generator/GeneratorException.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/generator/GeneratorException.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/generator/HttpGenerator.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/generator/HttpGenerator.java index 77464a860..c52ffc466 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/generator/HttpGenerator.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/generator/HttpGenerator.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/generator/SimpleHttpGenerator.java b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/generator/SimpleHttpGenerator.java index a1d955fd9..97eec6d1c 100644 --- a/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/generator/SimpleHttpGenerator.java +++ b/spring-xd-test-fixtures/src/main/java/org/springframework/xd/test/generator/SimpleHttpGenerator.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/test/java/org/springframework/xd/test/fixtures/TapTest.java b/spring-xd-test-fixtures/src/test/java/org/springframework/xd/test/fixtures/TapTest.java index 70d471605..f1ea63946 100644 --- a/spring-xd-test-fixtures/src/test/java/org/springframework/xd/test/fixtures/TapTest.java +++ b/spring-xd-test-fixtures/src/test/java/org/springframework/xd/test/fixtures/TapTest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test-fixtures/src/test/java/org/springframework/xd/test/fixtures/util/FixtureUtilsTests.java b/spring-xd-test-fixtures/src/test/java/org/springframework/xd/test/fixtures/util/FixtureUtilsTests.java index 49b7ebd74..aeac818ed 100644 --- a/spring-xd-test-fixtures/src/test/java/org/springframework/xd/test/fixtures/util/FixtureUtilsTests.java +++ b/spring-xd-test-fixtures/src/test/java/org/springframework/xd/test/fixtures/util/FixtureUtilsTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test/src/main/java/org/springframework/xd/dirt/integration/bus/BusTestUtils.java b/spring-xd-test/src/main/java/org/springframework/xd/dirt/integration/bus/BusTestUtils.java index 4da314c40..1ddca7110 100644 --- a/spring-xd-test/src/main/java/org/springframework/xd/dirt/integration/bus/BusTestUtils.java +++ b/spring-xd-test/src/main/java/org/springframework/xd/dirt/integration/bus/BusTestUtils.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test/src/main/java/org/springframework/xd/module/TestModuleDefinitions.java b/spring-xd-test/src/main/java/org/springframework/xd/module/TestModuleDefinitions.java index e5d0e84d2..a0b915a6d 100644 --- a/spring-xd-test/src/main/java/org/springframework/xd/module/TestModuleDefinitions.java +++ b/spring-xd-test/src/main/java/org/springframework/xd/module/TestModuleDefinitions.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test/src/main/java/org/springframework/xd/test/AbstractExternalResourceTestSupport.java b/spring-xd-test/src/main/java/org/springframework/xd/test/AbstractExternalResourceTestSupport.java index 668911c9f..27bbb589a 100644 --- a/spring-xd-test/src/main/java/org/springframework/xd/test/AbstractExternalResourceTestSupport.java +++ b/spring-xd-test/src/main/java/org/springframework/xd/test/AbstractExternalResourceTestSupport.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test/src/main/java/org/springframework/xd/test/HostNotWindowsRule.java b/spring-xd-test/src/main/java/org/springframework/xd/test/HostNotWindowsRule.java index 76892a63f..dbe5d1c67 100644 --- a/spring-xd-test/src/main/java/org/springframework/xd/test/HostNotWindowsRule.java +++ b/spring-xd-test/src/main/java/org/springframework/xd/test/HostNotWindowsRule.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test/src/main/java/org/springframework/xd/test/PackageSuiteRunner.java b/spring-xd-test/src/main/java/org/springframework/xd/test/PackageSuiteRunner.java index a0e081886..a1b668d6f 100644 --- a/spring-xd-test/src/main/java/org/springframework/xd/test/PackageSuiteRunner.java +++ b/spring-xd-test/src/main/java/org/springframework/xd/test/PackageSuiteRunner.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-test/src/main/java/org/springframework/xd/test/RandomConfigurationSupport.java b/spring-xd-test/src/main/java/org/springframework/xd/test/RandomConfigurationSupport.java index f0631830a..81e8488ea 100644 --- a/spring-xd-test/src/main/java/org/springframework/xd/test/RandomConfigurationSupport.java +++ b/spring-xd-test/src/main/java/org/springframework/xd/test/RandomConfigurationSupport.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test/src/main/java/org/springframework/xd/test/kafka/EmbeddedZookeeper.java b/spring-xd-test/src/main/java/org/springframework/xd/test/kafka/EmbeddedZookeeper.java index b6a3ba0ae..2d3415f26 100644 --- a/spring-xd-test/src/main/java/org/springframework/xd/test/kafka/EmbeddedZookeeper.java +++ b/spring-xd-test/src/main/java/org/springframework/xd/test/kafka/EmbeddedZookeeper.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test/src/main/java/org/springframework/xd/test/kafka/KafkaTestSupport.java b/spring-xd-test/src/main/java/org/springframework/xd/test/kafka/KafkaTestSupport.java index 6f30a9a0f..5efd66c69 100644 --- a/spring-xd-test/src/main/java/org/springframework/xd/test/kafka/KafkaTestSupport.java +++ b/spring-xd-test/src/main/java/org/springframework/xd/test/kafka/KafkaTestSupport.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test/src/main/java/org/springframework/xd/test/mqtt/MqttTestSupport.java b/spring-xd-test/src/main/java/org/springframework/xd/test/mqtt/MqttTestSupport.java index 6bc7cb47d..392751bdb 100644 --- a/spring-xd-test/src/main/java/org/springframework/xd/test/mqtt/MqttTestSupport.java +++ b/spring-xd-test/src/main/java/org/springframework/xd/test/mqtt/MqttTestSupport.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test/src/main/java/org/springframework/xd/test/rabbit/RabbitAdminTestSupport.java b/spring-xd-test/src/main/java/org/springframework/xd/test/rabbit/RabbitAdminTestSupport.java index be1d84667..f990aa053 100644 --- a/spring-xd-test/src/main/java/org/springframework/xd/test/rabbit/RabbitAdminTestSupport.java +++ b/spring-xd-test/src/main/java/org/springframework/xd/test/rabbit/RabbitAdminTestSupport.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test/src/main/java/org/springframework/xd/test/rabbit/RabbitTestSupport.java b/spring-xd-test/src/main/java/org/springframework/xd/test/rabbit/RabbitTestSupport.java index 83d3639ab..bc08479ba 100644 --- a/spring-xd-test/src/main/java/org/springframework/xd/test/rabbit/RabbitTestSupport.java +++ b/spring-xd-test/src/main/java/org/springframework/xd/test/rabbit/RabbitTestSupport.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-test/src/main/java/org/springframework/xd/test/redis/RedisTestSupport.java b/spring-xd-test/src/main/java/org/springframework/xd/test/redis/RedisTestSupport.java index e87768a05..f14dde950 100644 --- a/spring-xd-test/src/main/java/org/springframework/xd/test/redis/RedisTestSupport.java +++ b/spring-xd-test/src/main/java/org/springframework/xd/test/redis/RedisTestSupport.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/DefaultTuple.java b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/DefaultTuple.java index b545a68a5..50294fc17 100644 --- a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/DefaultTuple.java +++ b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/DefaultTuple.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/DefaultTupleConversionService.java b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/DefaultTupleConversionService.java index 366eee696..0258c0d18 100644 --- a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/DefaultTupleConversionService.java +++ b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/DefaultTupleConversionService.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/JsonBytesToTupleConverter.java b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/JsonBytesToTupleConverter.java index bad24893c..b2906ad2b 100644 --- a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/JsonBytesToTupleConverter.java +++ b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/JsonBytesToTupleConverter.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/JsonNodeToTupleConverter.java b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/JsonNodeToTupleConverter.java index 229125d89..2da1959bf 100644 --- a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/JsonNodeToTupleConverter.java +++ b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/JsonNodeToTupleConverter.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/JsonStringToTupleConverter.java b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/JsonStringToTupleConverter.java index c84bcad1d..7a0f752e0 100644 --- a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/JsonStringToTupleConverter.java +++ b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/JsonStringToTupleConverter.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/LocaleAwareStringToNumberConverterFactory.java b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/LocaleAwareStringToNumberConverterFactory.java index 2bc24a586..d7b83459c 100644 --- a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/LocaleAwareStringToNumberConverterFactory.java +++ b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/LocaleAwareStringToNumberConverterFactory.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/StringToDateConverter.java b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/StringToDateConverter.java index aa3d82e9c..2c20398f8 100644 --- a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/StringToDateConverter.java +++ b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/StringToDateConverter.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/Tuple.java b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/Tuple.java index a408c7eef..8bb6547a9 100644 --- a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/Tuple.java +++ b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/Tuple.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/TupleBuilder.java b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/TupleBuilder.java index 4a6e8c9d4..b90ce93e1 100644 --- a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/TupleBuilder.java +++ b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/TupleBuilder.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/TupleJsonMarshaller.java b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/TupleJsonMarshaller.java index 28fb65209..94f57b8a7 100644 --- a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/TupleJsonMarshaller.java +++ b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/TupleJsonMarshaller.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/TupleStringMarshaller.java b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/TupleStringMarshaller.java index f11bc8157..28b4bb775 100644 --- a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/TupleStringMarshaller.java +++ b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/TupleStringMarshaller.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/TupleToJsonStringConverter.java b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/TupleToJsonStringConverter.java index 33a07a8f1..fe7929a29 100644 --- a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/TupleToJsonStringConverter.java +++ b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/TupleToJsonStringConverter.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/batch/FieldSetType.java b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/batch/FieldSetType.java index 6d989e9f6..c11ddb61a 100644 --- a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/batch/FieldSetType.java +++ b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/batch/FieldSetType.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/batch/TupleFieldExtractor.java b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/batch/TupleFieldExtractor.java index ca4d556f8..4820b1edd 100644 --- a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/batch/TupleFieldExtractor.java +++ b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/batch/TupleFieldExtractor.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/batch/TupleFieldSetMapper.java b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/batch/TupleFieldSetMapper.java index 3e4116332..9f1a81e05 100644 --- a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/batch/TupleFieldSetMapper.java +++ b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/batch/TupleFieldSetMapper.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/batch/TupleRowMapper.java b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/batch/TupleRowMapper.java index 47e467f5d..91083e49b 100644 --- a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/batch/TupleRowMapper.java +++ b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/batch/TupleRowMapper.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/batch/TupleSqlParameterSource.java b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/batch/TupleSqlParameterSource.java index 1c2ab0cc2..e79dc651a 100644 --- a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/batch/TupleSqlParameterSource.java +++ b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/batch/TupleSqlParameterSource.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/batch/TupleSqlParameterSourceProvider.java b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/batch/TupleSqlParameterSourceProvider.java index 14bbb9a96..fa72148a7 100644 --- a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/batch/TupleSqlParameterSourceProvider.java +++ b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/batch/TupleSqlParameterSourceProvider.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/integration/JsonToTupleTransformer.java b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/integration/JsonToTupleTransformer.java index 21a105372..872cb728a 100644 --- a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/integration/JsonToTupleTransformer.java +++ b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/integration/JsonToTupleTransformer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/integration/MapToTupleTransformer.java b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/integration/MapToTupleTransformer.java index 3875c7555..a92de58da 100644 --- a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/integration/MapToTupleTransformer.java +++ b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/integration/MapToTupleTransformer.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/processor/TupleProcessor.java b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/processor/TupleProcessor.java index 2815c6206..788dad6a5 100644 --- a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/processor/TupleProcessor.java +++ b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/processor/TupleProcessor.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/serializer/kryo/DefaultTupleSerializer.java b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/serializer/kryo/DefaultTupleSerializer.java index 365a865e5..e540e3558 100644 --- a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/serializer/kryo/DefaultTupleSerializer.java +++ b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/serializer/kryo/DefaultTupleSerializer.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/serializer/kryo/TupleKryoRegistrar.java b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/serializer/kryo/TupleKryoRegistrar.java index 4dc7cc8a4..8cdccc693 100644 --- a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/serializer/kryo/TupleKryoRegistrar.java +++ b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/serializer/kryo/TupleKryoRegistrar.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/serializer/kryo/package-info.java b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/serializer/kryo/package-info.java index e1965e3fb..2c230cb86 100644 --- a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/serializer/kryo/package-info.java +++ b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/serializer/kryo/package-info.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/spel/TuplePropertyAccessor.java b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/spel/TuplePropertyAccessor.java index 080cb4d90..50ba2adb1 100644 --- a/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/spel/TuplePropertyAccessor.java +++ b/spring-xd-tuple/src/main/java/org/springframework/xd/tuple/spel/TuplePropertyAccessor.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/AbstractTupleMarshallerTests.java b/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/AbstractTupleMarshallerTests.java index 0c11bc25a..e865d21ec 100644 --- a/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/AbstractTupleMarshallerTests.java +++ b/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/AbstractTupleMarshallerTests.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/DefaultTupleTestForBatch.java b/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/DefaultTupleTestForBatch.java index 7a26c65f0..91562c557 100644 --- a/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/DefaultTupleTestForBatch.java +++ b/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/DefaultTupleTestForBatch.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/DefaultTupleTests.java b/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/DefaultTupleTests.java index aadf2be23..6cb713e46 100644 --- a/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/DefaultTupleTests.java +++ b/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/DefaultTupleTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/JsonBytesToTupleConverterTests.java b/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/JsonBytesToTupleConverterTests.java index 6e0f14c03..60ecdc703 100644 --- a/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/JsonBytesToTupleConverterTests.java +++ b/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/JsonBytesToTupleConverterTests.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/SpringToDateConverterTests.java b/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/SpringToDateConverterTests.java index 7f618f3c3..c74dd6323 100644 --- a/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/SpringToDateConverterTests.java +++ b/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/SpringToDateConverterTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/TupleJsonMarshallerTests.java b/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/TupleJsonMarshallerTests.java index 690c8a620..72e7dc903 100644 --- a/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/TupleJsonMarshallerTests.java +++ b/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/TupleJsonMarshallerTests.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/batch/TupleFieldExtractorTests.java b/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/batch/TupleFieldExtractorTests.java index b5e0680aa..f3afebb69 100644 --- a/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/batch/TupleFieldExtractorTests.java +++ b/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/batch/TupleFieldExtractorTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/batch/TupleFieldSetMapperTests.java b/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/batch/TupleFieldSetMapperTests.java index e52a3b7a7..509ba5d37 100644 --- a/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/batch/TupleFieldSetMapperTests.java +++ b/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/batch/TupleFieldSetMapperTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/batch/TupleRowMapperTests.java b/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/batch/TupleRowMapperTests.java index ec06601cc..4bc9208aa 100644 --- a/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/batch/TupleRowMapperTests.java +++ b/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/batch/TupleRowMapperTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/integration/JsonToTupleTransformerTests.java b/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/integration/JsonToTupleTransformerTests.java index 08c35e992..0ce3c327b 100644 --- a/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/integration/JsonToTupleTransformerTests.java +++ b/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/integration/JsonToTupleTransformerTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/integration/MapToTupleTransformerTests.java b/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/integration/MapToTupleTransformerTests.java index 815d70b4e..025d62f46 100644 --- a/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/integration/MapToTupleTransformerTests.java +++ b/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/integration/MapToTupleTransformerTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/serializer/kryo/TupleCodecTests.java b/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/serializer/kryo/TupleCodecTests.java index 82f7a0fc6..19c86883b 100644 --- a/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/serializer/kryo/TupleCodecTests.java +++ b/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/serializer/kryo/TupleCodecTests.java @@ -4,7 +4,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/spel/TuplePropertyAccessorTests.java b/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/spel/TuplePropertyAccessorTests.java index 08d095233..dbbe7ebeb 100644 --- a/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/spel/TuplePropertyAccessorTests.java +++ b/spring-xd-tuple/src/test/java/org/springframework/xd/tuple/spel/TuplePropertyAccessorTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/StandAloneUiApp.java b/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/StandAloneUiApp.java index d17a6927a..31191d740 100644 --- a/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/StandAloneUiApp.java +++ b/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/StandAloneUiApp.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except * in compliance with the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License * is distributed on an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express diff --git a/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/WebConfiguration.java b/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/WebConfiguration.java index 3a51d9e2c..e1616c761 100644 --- a/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/WebConfiguration.java +++ b/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/WebConfiguration.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except * in compliance with the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License * is distributed on an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express diff --git a/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/config/SecurityConfiguration.java b/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/config/SecurityConfiguration.java index bc8a71072..fd1504409 100644 --- a/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/config/SecurityConfiguration.java +++ b/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/config/SecurityConfiguration.java @@ -4,7 +4,7 @@ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the diff --git a/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/config/package-info.java b/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/config/package-info.java index ec19a3d85..98c2e8384 100644 --- a/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/config/package-info.java +++ b/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/config/package-info.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/controller/LoginController.java b/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/controller/LoginController.java index 3bc67ba59..10fad0e3c 100644 --- a/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/controller/LoginController.java +++ b/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/controller/LoginController.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/controller/package-info.java b/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/controller/package-info.java index b73d1d854..9564b85e2 100644 --- a/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/controller/package-info.java +++ b/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/controller/package-info.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/controller/support/AuthenticationRequest.java b/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/controller/support/AuthenticationRequest.java index 30d3a969c..cd32a3ef3 100644 --- a/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/controller/support/AuthenticationRequest.java +++ b/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/controller/support/AuthenticationRequest.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/controller/support/package-info.java b/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/controller/support/package-info.java index a1cd31b3a..0315d7d39 100644 --- a/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/controller/support/package-info.java +++ b/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/controller/support/package-info.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/package-info.java b/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/package-info.java index 203d97cf6..f890a49ed 100644 --- a/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/package-info.java +++ b/spring-xd-ui/src/main/java/org/springframework/xd/dirt/web/package-info.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-ui/src/test/java/org/springframework/xd/dirt/web/SecurityConfigurationTests.java b/spring-xd-ui/src/test/java/org/springframework/xd/dirt/web/SecurityConfigurationTests.java index c127e65e1..ac626fbca 100644 --- a/spring-xd-ui/src/test/java/org/springframework/xd/dirt/web/SecurityConfigurationTests.java +++ b/spring-xd-ui/src/test/java/org/springframework/xd/dirt/web/SecurityConfigurationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-ui/src/test/java/org/springframework/xd/dirt/web/SecurityDisabledConfigurationTests.java b/spring-xd-ui/src/test/java/org/springframework/xd/dirt/web/SecurityDisabledConfigurationTests.java index e7dc9d534..3a7e847b8 100644 --- a/spring-xd-ui/src/test/java/org/springframework/xd/dirt/web/SecurityDisabledConfigurationTests.java +++ b/spring-xd-ui/src/test/java/org/springframework/xd/dirt/web/SecurityDisabledConfigurationTests.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-yarn/spring-xd-yarn-appmaster/src/main/java/org/springframework/xd/yarn/AppmasterApplication.java b/spring-xd-yarn/spring-xd-yarn-appmaster/src/main/java/org/springframework/xd/yarn/AppmasterApplication.java index 9feb7d8c5..131405c68 100644 --- a/spring-xd-yarn/spring-xd-yarn-appmaster/src/main/java/org/springframework/xd/yarn/AppmasterApplication.java +++ b/spring-xd-yarn/spring-xd-yarn-appmaster/src/main/java/org/springframework/xd/yarn/AppmasterApplication.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-yarn/spring-xd-yarn-appmaster/src/main/java/org/springframework/xd/yarn/XdAppmaster.java b/spring-xd-yarn/spring-xd-yarn-appmaster/src/main/java/org/springframework/xd/yarn/XdAppmaster.java index bb0ca8bc9..9d3ecf4c7 100644 --- a/spring-xd-yarn/spring-xd-yarn-appmaster/src/main/java/org/springframework/xd/yarn/XdAppmaster.java +++ b/spring-xd-yarn/spring-xd-yarn-appmaster/src/main/java/org/springframework/xd/yarn/XdAppmaster.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-yarn/spring-xd-yarn-client/src/main/java/org/springframework/xd/yarn/ClientApplication.java b/spring-xd-yarn/spring-xd-yarn-client/src/main/java/org/springframework/xd/yarn/ClientApplication.java index 985ffae4e..d372a10da 100644 --- a/spring-xd-yarn/spring-xd-yarn-client/src/main/java/org/springframework/xd/yarn/ClientApplication.java +++ b/spring-xd-yarn/spring-xd-yarn-client/src/main/java/org/springframework/xd/yarn/ClientApplication.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-yarn/spring-xd-yarn-client/src/main/java/org/springframework/xd/yarn/XdYarnAdminInfoCommand.java b/spring-xd-yarn/spring-xd-yarn-client/src/main/java/org/springframework/xd/yarn/XdYarnAdminInfoCommand.java index 6ab2319a7..e4c8a184c 100644 --- a/spring-xd-yarn/spring-xd-yarn-client/src/main/java/org/springframework/xd/yarn/XdYarnAdminInfoCommand.java +++ b/spring-xd-yarn/spring-xd-yarn-client/src/main/java/org/springframework/xd/yarn/XdYarnAdminInfoCommand.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/spring-xd-yarn/spring-xd-yarn-client/src/main/java/org/springframework/xd/yarn/XdYarnClusterCreateCommand.java b/spring-xd-yarn/spring-xd-yarn-client/src/main/java/org/springframework/xd/yarn/XdYarnClusterCreateCommand.java index 440df2c85..f6817d80a 100644 --- a/spring-xd-yarn/spring-xd-yarn-client/src/main/java/org/springframework/xd/yarn/XdYarnClusterCreateCommand.java +++ b/spring-xd-yarn/spring-xd-yarn-client/src/main/java/org/springframework/xd/yarn/XdYarnClusterCreateCommand.java @@ -5,7 +5,7 @@ * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * - * http://www.apache.org/licenses/LICENSE-2.0 + * https://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, diff --git a/src/docs/asciidoc/Introduction.asciidoc b/src/docs/asciidoc/Introduction.asciidoc index 7454f87a1..d2e2c24ed 100644 --- a/src/docs/asciidoc/Introduction.asciidoc +++ b/src/docs/asciidoc/Introduction.asciidoc @@ -3,7 +3,7 @@ === Overview -Spring XD is a unified, distributed, and extensible service for data ingestion, real time analytics, batch processing, and data export. The Spring XD project is an open source http://www.apache.org/licenses/LICENSE-2.0[Apache 2 License] licenced project whose goal is to tackle big data complexity. Much of the complexity in building real-world big data applications is related to integrating many disparate systems into one cohesive solution across a range of use-cases. +Spring XD is a unified, distributed, and extensible service for data ingestion, real time analytics, batch processing, and data export. The Spring XD project is an open source https://www.apache.org/licenses/LICENSE-2.0[Apache 2 License] licenced project whose goal is to tackle big data complexity. Much of the complexity in building real-world big data applications is related to integrating many disparate systems into one cohesive solution across a range of use-cases. Common use-cases encountered in creating a comprehensive big data solution are * High throughput distributed data ingestion from a variety of input sources into big data store such as HDFS or Splunk diff --git a/src/etc/header.txt b/src/etc/header.txt index deb6adcc0..6da2d670c 100644 --- a/src/etc/header.txt +++ b/src/etc/header.txt @@ -4,7 +4,7 @@ Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with the License. You may obtain a copy of the License at -http://www.apache.org/licenses/LICENSE-2.0 +https://www.apache.org/licenses/LICENSE-2.0 Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on an "AS IS" BASIS,