From 6b3fcef3f4c3b10166db3edec8ea0ecf462bf75e Mon Sep 17 00:00:00 2001 From: Ponfee Date: Wed, 14 Feb 2024 11:08:24 +0800 Subject: [PATCH] modify copyright --- .../admin/DisjobAdminConfiguration.java | 22 ++++++++---- .../controller/DisjobInstanceController.java | 22 ++++++++---- .../admin/controller/DisjobJobController.java | 22 ++++++++---- .../controller/DisjobMgGroupController.java | 22 ++++++++---- .../controller/DisjobMyGroupController.java | 22 ++++++++---- .../controller/SupervisorInfoController.java | 22 ++++++++---- .../disjob/admin/export/SchedJobExport.java | 22 ++++++++---- .../disjob/admin/service/DisjobService.java | 22 ++++++++---- .../ponfee/disjob/admin/util/PageUtils.java | 22 ++++++++---- .../properties/SimpleJdbcProperties.java | 22 ++++++++---- .../disjob/common/base/ConsistentHash.java | 22 ++++++++---- .../disjob/common/base/Destroyable.java | 22 ++++++++---- .../disjob/common/base/IdGenerator.java | 22 ++++++++---- .../disjob/common/base/Initializable.java | 22 ++++++++---- .../disjob/common/base/IntValueDesc.java | 22 ++++++++---- .../disjob/common/base/IntValueEnum.java | 22 ++++++++---- .../ponfee/disjob/common/base/LazyLoader.java | 22 ++++++++---- .../common/base/NoArgMethodInvoker.java | 22 ++++++++---- .../cn/ponfee/disjob/common/base/Null.java | 22 ++++++++---- .../common/base/RetryInvocationHandler.java | 22 ++++++++---- .../disjob/common/base/RetryTemplate.java | 22 ++++++++---- .../common/base/SingletonClassConstraint.java | 22 ++++++++---- .../ponfee/disjob/common/base/Startable.java | 22 ++++++++---- .../cn/ponfee/disjob/common/base/Symbol.java | 22 ++++++++---- .../disjob/common/base/TextTokenizer.java | 22 ++++++++---- .../disjob/common/base/TimingWheel.java | 22 ++++++++---- .../disjob/common/base/ToJsonString.java | 22 ++++++++---- .../ponfee/disjob/common/base/ValueEnum.java | 22 ++++++++---- .../disjob/common/collect/ArrayHashKey.java | 22 ++++++++---- .../disjob/common/collect/Collects.java | 22 ++++++++---- .../collect/DelegatedIntSpliterator.java | 22 ++++++++---- .../common/collect/ImmutableArrayList.java | 22 ++++++++---- .../common/collect/ImmutableHashList.java | 22 ++++++++---- .../common/collect/PooledObjectProcessor.java | 22 ++++++++---- .../collect/RemovableTypedKeyValue.java | 22 ++++++++---- .../common/collect/RemovableTypedMap.java | 22 ++++++++---- .../disjob/common/collect/TypedKeyValue.java | 22 ++++++++---- .../disjob/common/collect/TypedMap.java | 22 ++++++++---- .../concurrent/AbstractHeartbeatThread.java | 22 ++++++++---- .../concurrent/AsyncDelayedExecutor.java | 22 ++++++++---- .../disjob/common/concurrent/DelayedData.java | 22 ++++++++---- .../LoggedUncaughtExceptionHandler.java | 22 ++++++++---- .../disjob/common/concurrent/LoopThread.java | 22 ++++++++---- .../concurrent/MultithreadExecutors.java | 22 ++++++++---- .../common/concurrent/NamedThreadFactory.java | 22 ++++++++---- .../concurrent/ThreadPoolExecutors.java | 22 ++++++++---- .../disjob/common/concurrent/Threads.java | 22 ++++++++---- .../cn/ponfee/disjob/common/dag/DAGEdge.java | 22 ++++++++---- .../common/dag/DAGExpressionParser.java | 22 ++++++++---- .../cn/ponfee/disjob/common/dag/DAGNode.java | 22 ++++++++---- .../disjob/common/date/DatePeriods.java | 22 ++++++++---- .../cn/ponfee/disjob/common/date/Dates.java | 22 ++++++++---- .../disjob/common/date/JacksonDate.java | 22 ++++++++---- .../common/date/JavaUtilDateFormat.java | 22 ++++++++---- .../disjob/common/date/LocalDateFormat.java | 22 ++++++++---- .../common/date/LocalDateTimeFormat.java | 22 ++++++++---- .../common/exception/BaseException.java | 22 ++++++++---- .../exception/BaseRuntimeException.java | 22 ++++++++---- .../disjob/common/exception/Throwables.java | 22 ++++++++---- .../common/lock/DoInDatabaseLocked.java | 22 ++++++++---- .../ponfee/disjob/common/lock/DoInLocked.java | 22 ++++++++---- .../disjob/common/lock/DoInRedisLocked.java | 22 ++++++++---- .../ponfee/disjob/common/lock/RedisLock.java | 22 ++++++++---- .../disjob/common/lock/RedisLockFactory.java | 22 ++++++++---- .../disjob/common/model/BaseEntity.java | 22 ++++++++---- .../ponfee/disjob/common/model/CodeMsg.java | 22 ++++++++---- .../disjob/common/model/PageRequest.java | 22 ++++++++---- .../disjob/common/model/PageResponse.java | 22 ++++++++---- .../cn/ponfee/disjob/common/model/Result.java | 22 ++++++++---- .../disjob/common/spring/BaseController.java | 22 ++++++++---- .../spring/EnableJacksonDateConfigurer.java | 22 ++++++++---- .../common/spring/JdbcTemplateWrapper.java | 22 ++++++++---- .../LocalizedMethodArgumentConfigurer.java | 22 ++++++++---- .../LocalizedMethodArgumentResolver.java | 22 ++++++++---- .../spring/LocalizedMethodArgumentUtils.java | 22 ++++++++---- .../spring/LocalizedMethodArguments.java | 22 ++++++++---- .../disjob/common/spring/RedisKeyRenewal.java | 22 ++++++++---- .../common/spring/RedisTemplateUtils.java | 22 ++++++++---- .../disjob/common/spring/ResourceScanner.java | 22 ++++++++---- .../common/spring/RestTemplateUtils.java | 22 ++++++++---- .../disjob/common/spring/RpcController.java | 22 ++++++++---- .../common/spring/SpringContextHolder.java | 22 ++++++++---- .../disjob/common/spring/SpringUtils.java | 22 ++++++++---- .../common/spring/TransactionUtils.java | 22 ++++++++---- .../disjob/common/spring/YamlProperties.java | 22 ++++++++---- .../spring/YamlPropertySourceFactory.java | 22 ++++++++---- .../ponfee/disjob/common/tree/BaseNode.java | 22 ++++++++---- .../ponfee/disjob/common/tree/FlatNode.java | 22 ++++++++---- .../disjob/common/tree/MapTreeTrait.java | 22 ++++++++---- .../cn/ponfee/disjob/common/tree/NodeId.java | 22 ++++++++---- .../ponfee/disjob/common/tree/NodePath.java | 22 ++++++++---- .../ponfee/disjob/common/tree/PlainNode.java | 22 ++++++++---- .../common/tree/SiblingNodesComparator.java | 22 ++++++++---- .../ponfee/disjob/common/tree/TreeNode.java | 22 ++++++++---- .../disjob/common/tree/TreeNodeBuilder.java | 22 ++++++++---- .../ponfee/disjob/common/tree/TreeTrait.java | 22 ++++++++---- .../common/tree/print/BinaryTreePrinter.java | 22 ++++++++---- .../tree/print/MultiwayTreePrinter.java | 22 ++++++++---- .../cn/ponfee/disjob/common/tuple/Tuple.java | 22 ++++++++---- .../cn/ponfee/disjob/common/tuple/Tuple0.java | 22 ++++++++---- .../cn/ponfee/disjob/common/tuple/Tuple1.java | 22 ++++++++---- .../cn/ponfee/disjob/common/tuple/Tuple2.java | 22 ++++++++---- .../cn/ponfee/disjob/common/tuple/Tuple3.java | 22 ++++++++---- .../cn/ponfee/disjob/common/tuple/Tuple4.java | 22 ++++++++---- .../cn/ponfee/disjob/common/util/Bytes.java | 22 ++++++++---- .../ponfee/disjob/common/util/ClassUtils.java | 22 ++++++++---- .../disjob/common/util/Comparators.java | 22 ++++++++---- .../cn/ponfee/disjob/common/util/Enums.java | 22 ++++++++---- .../cn/ponfee/disjob/common/util/Fields.java | 22 ++++++++---- .../cn/ponfee/disjob/common/util/Files.java | 22 ++++++++---- .../ponfee/disjob/common/util/Functions.java | 22 ++++++++---- .../disjob/common/util/GenericUtils.java | 22 ++++++++---- .../disjob/common/util/GroovyUtils.java | 22 ++++++++---- .../cn/ponfee/disjob/common/util/Jsons.java | 22 ++++++++---- .../cn/ponfee/disjob/common/util/Maths.java | 22 ++++++++---- .../disjob/common/util/MavenProjects.java | 22 ++++++++---- .../ponfee/disjob/common/util/NetUtils.java | 22 ++++++++---- .../cn/ponfee/disjob/common/util/Numbers.java | 22 ++++++++---- .../disjob/common/util/ObjectUtils.java | 22 ++++++++---- .../ponfee/disjob/common/util/Predicates.java | 22 ++++++++---- .../disjob/common/util/PrimitiveTypes.java | 22 ++++++++---- .../disjob/common/util/ProcessUtils.java | 22 ++++++++---- .../ponfee/disjob/common/util/ProxyUtils.java | 22 ++++++++---- .../disjob/common/util/SleepWaitUtils.java | 22 ++++++++---- .../cn/ponfee/disjob/common/util/Strings.java | 22 ++++++++---- .../disjob/common/util/SystemUtils.java | 22 ++++++++---- .../ponfee/disjob/common/util/URLCodes.java | 22 ++++++++---- .../ponfee/disjob/common/util/UuidUtils.java | 22 ++++++++---- .../base/ClassSingletonInstanceTest.java | 22 ++++++++---- .../common/dag/DAGExpressionParserTest.java | 22 ++++++++---- .../ponfee/disjob/common/dag/DAGPrinter.java | 22 ++++++++---- .../common/date/DatePeriodCalculatorTest.java | 22 ++++++++---- .../ponfee/disjob/common/date/DatesTest.java | 22 ++++++++---- .../common/date/JavaUtilDateFormatTest.java | 22 ++++++++---- .../common/date/LocalDateTimeFormatTest.java | 22 ++++++++---- .../common/spring/ResourceScannerTest.java | 26 +++++++++----- .../ponfee/disjob/common/util/BytesTest.java | 22 ++++++++---- .../disjob/common/util/CollectsTest.java | 22 ++++++++---- .../disjob/common/util/CopyrightTest.java | 34 ++++++++++++------- .../ponfee/disjob/common/util/FilesTest.java | 22 ++++++++---- .../disjob/common/util/GroovyUtilsTest.java | 22 ++++++++---- .../disjob/common/util/HashFunctionTest.java | 22 ++++++++---- .../ponfee/disjob/common/util/JsonsTest.java | 22 ++++++++---- .../common/util/MavenDependencyTest.java | 22 ++++++++---- .../disjob/common/util/ProxyUtilsTest.java | 22 ++++++++---- .../disjob/common/util/StringsTest.java | 22 ++++++++---- .../disjob/common/util/TextTokenizerTest.java | 22 ++++++++---- .../disjob/core/base/HttpProperties.java | 22 ++++++++---- .../ponfee/disjob/core/base/JobCodeMsg.java | 22 ++++++++---- .../ponfee/disjob/core/base/JobConstants.java | 22 ++++++++---- .../disjob/core/base/RetryProperties.java | 22 ++++++++---- .../cn/ponfee/disjob/core/base/Server.java | 22 ++++++++---- .../ponfee/disjob/core/base/Supervisor.java | 22 ++++++++---- .../disjob/core/base/SupervisorMetrics.java | 22 ++++++++---- .../core/base/SupervisorRpcService.java | 22 ++++++++---- .../cn/ponfee/disjob/core/base/Tokens.java | 22 ++++++++---- .../cn/ponfee/disjob/core/base/Worker.java | 22 ++++++++---- .../disjob/core/base/WorkerMetrics.java | 22 ++++++++---- .../disjob/core/base/WorkerRpcService.java | 22 ++++++++---- .../disjob/core/enums/CollidedStrategy.java | 22 ++++++++---- .../disjob/core/enums/ExecuteState.java | 22 ++++++++---- .../cn/ponfee/disjob/core/enums/JobState.java | 22 ++++++++---- .../cn/ponfee/disjob/core/enums/JobType.java | 22 ++++++++---- .../disjob/core/enums/MisfireStrategy.java | 22 ++++++++---- .../ponfee/disjob/core/enums/Operation.java | 22 ++++++++---- .../ponfee/disjob/core/enums/RetryType.java | 22 ++++++++---- .../disjob/core/enums/RouteStrategy.java | 22 ++++++++---- .../cn/ponfee/disjob/core/enums/RunState.java | 22 ++++++++---- .../cn/ponfee/disjob/core/enums/RunType.java | 22 ++++++++---- .../ponfee/disjob/core/enums/TriggerType.java | 22 ++++++++---- .../core/event/TaskDispatchFailedEvent.java | 22 ++++++++---- .../exception/AuthenticationException.java | 22 ++++++++---- .../core/exception/CancelTaskException.java | 22 ++++++++---- .../exception/GroupNotFoundException.java | 22 ++++++++---- .../disjob/core/exception/JobException.java | 22 ++++++++---- .../core/exception/JobRuntimeException.java | 22 ++++++++---- .../core/exception/KeyExistsException.java | 22 ++++++++---- .../core/exception/KeyNotExistsException.java | 22 ++++++++---- .../core/exception/PauseTaskException.java | 22 ++++++++---- .../core/handle/BroadcastJobHandler.java | 22 ++++++++---- .../disjob/core/handle/ExecuteResult.java | 22 ++++++++---- .../ponfee/disjob/core/handle/JobHandler.java | 22 ++++++++---- .../disjob/core/handle/JobHandlerUtils.java | 22 ++++++++---- .../disjob/core/handle/JobSplitter.java | 22 ++++++++---- .../ponfee/disjob/core/handle/Savepoint.java | 22 ++++++++---- .../ponfee/disjob/core/handle/SplitTask.java | 22 ++++++++---- .../disjob/core/handle/TaskExecutor.java | 22 ++++++++---- .../execution/AbstractExecutionTask.java | 22 ++++++++---- .../core/handle/execution/ExecutedTask.java | 22 ++++++++---- .../core/handle/execution/ExecutingTask.java | 22 ++++++++---- .../execution/ExecutionTaskConverter.java | 22 ++++++++---- .../execution/WorkflowPredecessorNode.java | 22 ++++++++---- .../core/handle/impl/CommandJobHandler.java | 22 ++++++++---- .../core/handle/impl/GroovyJobHandler.java | 22 ++++++++---- .../core/handle/impl/HttpJobHandler.java | 22 ++++++++---- .../core/handle/impl/ScriptJobHandler.java | 22 ++++++++---- .../disjob/core/model/InstanceAttach.java | 22 ++++++++---- .../disjob/core/model/PeriodTriggerValue.java | 22 ++++++++---- .../ponfee/disjob/core/model/SchedDepend.java | 22 ++++++++---- .../ponfee/disjob/core/model/SchedGroup.java | 22 ++++++++---- .../disjob/core/model/SchedInstance.java | 22 ++++++++---- .../cn/ponfee/disjob/core/model/SchedJob.java | 22 ++++++++---- .../ponfee/disjob/core/model/SchedTask.java | 22 ++++++++---- .../disjob/core/model/SchedWorkflow.java | 22 ++++++++---- .../ponfee/disjob/core/model/TokenType.java | 22 ++++++++---- .../core/param/supervisor/EventParam.java | 22 ++++++++---- .../core/param/supervisor/StartTaskParam.java | 22 ++++++++---- .../param/supervisor/TerminateTaskParam.java | 22 ++++++++---- .../supervisor/UpdateTaskWorkerParam.java | 22 ++++++++---- .../param/worker/AuthenticationParam.java | 22 ++++++++---- .../param/worker/ConfigureWorkerParam.java | 22 ++++++++---- .../core/param/worker/GetMetricsParam.java | 22 ++++++++---- .../core/param/worker/JobHandlerParam.java | 22 ++++++++---- .../cn/ponfee/disjob/core/util/JobUtils.java | 22 ++++++++---- .../ponfee/disjob/core/base/ServerTest.java | 22 ++++++++---- .../ponfee/disjob/core/base/TokensTest.java | 22 ++++++++---- .../disjob/core/enums/ExecuteStateTest.java | 22 ++++++++---- .../core/handle/CommandJobHandlerTest.java | 22 ++++++++---- .../ponfee/disjob/core/handle/EnumTest.java | 22 ++++++++---- .../disjob/core/handle/ExecuteResultTest.java | 22 ++++++++---- .../core/handle/HttpJobHandlerTest.java | 22 ++++++++---- .../core/handle/ScriptJobHandlerTest.java | 22 ++++++++---- .../execution/ExecutionTaskConverterTest.java | 22 ++++++++---- .../disjob/dispatch/DispatchTaskParam.java | 22 ++++++++---- .../disjob/dispatch/ExecuteTaskParam.java | 22 ++++++++---- .../dispatch/TaskDispatchException.java | 22 ++++++++---- .../disjob/dispatch/TaskDispatcher.java | 22 ++++++++---- .../ponfee/disjob/dispatch/TaskReceiver.java | 22 ++++++++---- .../BaseTaskDispatchingAutoConfiguration.java | 22 ++++++++---- .../route/BroadcastExecutionRouter.java | 22 ++++++++---- .../route/ConsistentHashExecutionRouter.java | 22 ++++++++---- .../dispatch/route/ExecutionRouter.java | 22 ++++++++---- .../route/ExecutionRouterException.java | 22 ++++++++---- .../route/ExecutionRouterRegistrar.java | 22 ++++++++---- .../route/LocalPriorityExecutionRouter.java | 22 ++++++++---- .../dispatch/route/RandomExecutionRouter.java | 22 ++++++++---- .../route/RoundRobinExecutionRouter.java | 22 ++++++++---- .../route/SimpleHashExecutionRouter.java | 22 ++++++++---- .../dispatch/route/count/AtomicCounter.java | 22 ++++++++---- .../route/count/JdkAtomicCounter.java | 22 ++++++++---- .../route/count/RedisAtomicCounter.java | 22 ++++++++---- .../ConsistentHashExecutionRouterTest.java | 22 ++++++++---- .../dispatch/http/HttpTaskDispatcher.java | 22 ++++++++---- .../dispatch/http/HttpTaskReceiver.java | 22 ++++++++---- .../http/HttpTaskReceiverService.java | 22 ++++++++---- .../HttpTaskDispatchingAutoConfiguration.java | 22 ++++++++---- .../dispatch/redis/RedisTaskDispatcher.java | 22 ++++++++---- .../redis/RedisTaskDispatchingUtils.java | 22 ++++++++---- .../dispatch/redis/RedisTaskReceiver.java | 22 ++++++++---- ...RedisTaskDispatchingAutoConfiguration.java | 22 ++++++++---- .../ClockMovedBackwardsException.java | 22 ++++++++---- .../ponfee/disjob/id/snowflake/Snowflake.java | 22 ++++++++---- .../snowflake/db/DbDistributedSnowflake.java | 22 ++++++++---- .../id/snowflake/db/DbSnowflakeWorker.java | 22 ++++++++---- .../disjob/id/snowflake/zk/ZkConfig.java | 22 ++++++++---- .../snowflake/zk/ZkDistributedSnowflake.java | 22 ++++++++---- .../snowflake/DbDistributedSnowflakeTest.java | 22 ++++++++---- .../disjob/id/snowflake/SnowflakeTest.java | 22 ++++++++---- .../snowflake/ZkDistributedSnowflakeTest.java | 22 ++++++++---- .../registry/AbstractRegistryProperties.java | 22 ++++++++---- .../registry/ConnectionStateListener.java | 22 ++++++++---- .../cn/ponfee/disjob/registry/Discovery.java | 22 ++++++++---- .../cn/ponfee/disjob/registry/EventType.java | 22 ++++++++---- .../cn/ponfee/disjob/registry/Registry.java | 22 ++++++++---- .../disjob/registry/RegistryException.java | 22 ++++++++---- .../disjob/registry/ServerRegistry.java | 22 ++++++++---- .../cn/ponfee/disjob/registry/ServerRole.java | 22 ++++++++---- .../disjob/registry/SupervisorRegistry.java | 22 ++++++++---- .../disjob/registry/WorkerRegistry.java | 22 ++++++++---- .../BaseServerRegistryAutoConfiguration.java | 22 ++++++++---- .../registry/discovery/DiscoveryServer.java | 22 ++++++++---- .../discovery/DiscoverySupervisor.java | 22 ++++++++---- .../registry/discovery/DiscoveryWorker.java | 22 ++++++++---- .../rpc/DestinationServerRestProxy.java | 22 ++++++++---- .../rpc/DestinationServerRestTemplate.java | 22 ++++++++---- .../rpc/DiscoveryServerRestProxy.java | 22 ++++++++---- .../rpc/DiscoveryServerRestTemplate.java | 22 ++++++++---- .../registry/rpc/RpcInvokeException.java | 22 ++++++++---- .../ponfee/disjob/common/util/RetryTest.java | 22 ++++++++---- .../registry/consul/ConsulServerRegistry.java | 22 ++++++++---- .../consul/ConsulSupervisorRegistry.java | 22 ++++++++---- .../registry/consul/ConsulWorkerRegistry.java | 22 ++++++++---- .../ConsulRegistryProperties.java | 22 ++++++++---- ...ConsulServerRegistryAutoConfiguration.java | 22 ++++++++---- .../consul/EmbeddedConsulServerPszymczyk.java | 22 ++++++++---- .../EmbeddedConsulServerTestcontainers.java | 22 ++++++++---- .../database/DatabaseServerRegistry.java | 22 ++++++++---- .../database/DatabaseSupervisorRegistry.java | 22 ++++++++---- .../database/DatabaseWorkerRegistry.java | 22 ++++++++---- .../DatabaseRegistryProperties.java | 22 ++++++++---- ...tabaseServerRegistryAutoConfiguration.java | 22 ++++++++---- .../disjob/registry/etcd/EtcdClient.java | 22 ++++++++---- .../registry/etcd/EtcdServerRegistry.java | 22 ++++++++---- .../registry/etcd/EtcdSupervisorRegistry.java | 22 ++++++++---- .../registry/etcd/EtcdWorkerRegistry.java | 22 ++++++++---- .../configuration/EtcdRegistryProperties.java | 22 ++++++++---- .../EtcdServerRegistryAutoConfiguration.java | 22 ++++++++---- .../EmbeddedEtcdServerTestcontainers.java | 22 ++++++++---- .../registry/nacos/NacosServerRegistry.java | 22 ++++++++---- .../nacos/NacosSupervisorRegistry.java | 22 ++++++++---- .../registry/nacos/NacosWorkerRegistry.java | 22 ++++++++---- .../NacosRegistryProperties.java | 22 ++++++++---- .../NacosServerRegistryAutoConfiguration.java | 22 ++++++++---- .../EmbeddedNacosServerTestcontainers.java | 22 ++++++++---- .../registry/redis/RedisServerRegistry.java | 22 ++++++++---- .../redis/RedisSupervisorRegistry.java | 22 ++++++++---- .../registry/redis/RedisWorkerRegistry.java | 22 ++++++++---- .../RedisRegistryProperties.java | 22 ++++++++---- .../RedisServerRegistryAutoConfiguration.java | 22 ++++++++---- .../zookeeper/CuratorFrameworkClient.java | 22 ++++++++---- .../zookeeper/ZookeeperServerRegistry.java | 22 ++++++++---- .../ZookeeperSupervisorRegistry.java | 22 ++++++++---- .../zookeeper/ZookeeperWorkerRegistry.java | 22 ++++++++---- .../ZookeeperRegistryProperties.java | 22 ++++++++---- ...keeperServerRegistryAutoConfiguration.java | 22 ++++++++---- .../zookeeper/EmbeddedZookeeperServer.java | 22 ++++++++---- .../samples/worker/WorkerFramelessMain.java | 22 ++++++++---- .../redis/AbstractRedisTemplateCreator.java | 22 ++++++++---- .../redis/ClusterRedisTemplateCreator.java | 22 ++++++++---- .../redis/SentinelRedisTemplateCreator.java | 22 ++++++++---- .../redis/StandaloneRedisTemplateCreator.java | 22 ++++++++---- .../samples/worker/util/JobHandlerParser.java | 22 ++++++++---- .../samples/worker/vertx/VertxWebServer.java | 22 ++++++++---- .../common/AbstractSamplesApplication.java | 22 ++++++++---- .../configuration/SpringWebConfiguration.java | 23 +++++++++---- .../SpringWebExceptionHandler.java | 22 ++++++++---- .../samples/merged/MergedApplication.java | 22 ++++++++---- .../supervisor/SupervisorApplication.java | 22 ++++++++---- .../samples/worker/WorkerApplication.java | 22 ++++++++---- .../disjob/supervisor/SupervisorStartup.java | 22 ++++++++---- .../application/AuthorizeGroupService.java | 22 ++++++++---- .../application/EventSubscribeService.java | 22 ++++++++---- .../application/OpenapiService.java | 22 ++++++++---- .../application/SchedGroupService.java | 22 ++++++++---- .../application/ServerInvokeService.java | 22 ++++++++---- .../application/converter/CommonMapper.java | 22 ++++++++---- .../converter/SchedGroupConverter.java | 22 ++++++++---- .../converter/SchedJobConverter.java | 22 ++++++++---- .../converter/ServerMetricsConverter.java | 22 ++++++++---- .../request/AbstractSchedJobRequest.java | 22 ++++++++---- .../request/ConfigureAllWorkerRequest.java | 22 ++++++++---- .../request/ConfigureOneWorkerRequest.java | 22 ++++++++---- .../request/SchedGroupAddRequest.java | 22 ++++++++---- .../request/SchedGroupPageRequest.java | 22 ++++++++---- .../request/SchedGroupUpdateRequest.java | 22 ++++++++---- .../request/SchedInstancePageRequest.java | 22 ++++++++---- .../request/SchedJobAddRequest.java | 22 ++++++++---- .../request/SchedJobPageRequest.java | 22 ++++++++---- .../request/SchedJobSearchRequest.java | 22 ++++++++---- .../request/SchedJobUpdateRequest.java | 22 ++++++++---- .../response/SchedGroupResponse.java | 22 ++++++++---- .../response/SchedInstanceResponse.java | 22 ++++++++---- .../response/SchedJobResponse.java | 22 ++++++++---- .../response/SchedTaskResponse.java | 22 ++++++++---- .../response/ServerMetricsResponse.java | 22 ++++++++---- .../response/SupervisorMetricsResponse.java | 22 ++++++++---- .../response/WorkerMetricsResponse.java | 22 ++++++++---- .../application/value/DisjobGroup.java | 22 ++++++++---- .../auth/AuthenticationConfigurer.java | 22 ++++++++---- .../auth/SupervisorAuthentication.java | 22 ++++++++---- .../base/AbstractDataSourceConfig.java | 22 ++++++++---- .../base/AbstractDataSourceConfig.java.bak | 22 ++++++++---- .../supervisor/base/SupervisorConstants.java | 22 ++++++++---- .../component/AbstractJobManager.java | 22 ++++++++---- .../component/DistributedJobManager.java | 22 ++++++++---- .../component/DistributedJobQuerier.java | 22 ++++++++---- .../configuration/EnableSupervisor.java | 22 ++++++++---- .../configuration/SupervisorLifecycle.java | 22 ++++++++---- .../configuration/SupervisorProperties.java | 22 ++++++++---- .../disjob/supervisor/dag/WorkflowGraph.java | 22 ++++++++---- .../dao/SupervisorDataSourceConfig.java | 22 ++++++++---- .../dao/mapper/SchedDependMapper.java | 22 ++++++++---- .../dao/mapper/SchedGroupMapper.java | 22 ++++++++---- .../dao/mapper/SchedInstanceMapper.java | 22 ++++++++---- .../supervisor/dao/mapper/SchedJobMapper.java | 22 ++++++++---- .../dao/mapper/SchedTaskMapper.java | 22 ++++++++---- .../dao/mapper/SchedWorkflowMapper.java | 22 ++++++++---- .../instance/GeneralInstanceCreator.java | 22 ++++++++---- .../supervisor/instance/TriggerInstance.java | 22 ++++++++---- .../instance/TriggerInstanceCreator.java | 22 ++++++++---- .../instance/WorkflowInstanceCreator.java | 22 ++++++++---- .../provider/SupervisorOpenapiProvider.java | 22 ++++++++---- .../provider/SupervisorRpcProvider.java | 22 ++++++++---- .../thread/RunningInstanceScanner.java | 22 ++++++++---- .../thread/TriggeringJobScanner.java | 22 ++++++++---- .../thread/WaitingInstanceScanner.java | 22 ++++++++---- .../supervisor/util/TriggerTimeUtils.java | 22 ++++++++---- .../java/cn/ponfee/disjob/AllTestSuite.java | 22 ++++++++---- .../supervisor/SpringBootTestApplication.java | 22 ++++++++---- .../disjob/supervisor/SpringBootTestBase.java | 22 ++++++++---- .../supervisor/SpringBootTestCollector.java | 22 ++++++++---- .../application/ModelClassFileDiffTest.java | 22 ++++++++---- .../supervisor/base/RateLimiterTest.java | 22 ++++++++---- .../disjob/supervisor/base/RedisLockTest.java | 22 ++++++++---- .../supervisor/base/SpringContextTest.java | 22 ++++++++---- .../supervisor/base/ThreadExceptionTest.java | 22 ++++++++---- .../supervisor/base/WorkerRpcServiceTest.java | 22 ++++++++---- .../config/AuthenticationCallWorker.java | 23 +++++++++---- .../config/CommonConfiguration.java | 22 ++++++++---- .../config/DisjobConfiguration.java | 22 ++++++++---- .../InitializedContextCustomizerFactory.java | 23 +++++++++---- .../supervisor/config/WebsocketDemo.java | 22 ++++++++---- .../supervisor/model/ExecuteParamTest.java | 22 ++++++++---- .../disjob/supervisor/model/RouteTest.java | 22 ++++++++---- .../supervisor/model/SchedJobMapperTest.java | 22 ++++++++---- .../supervisor/model/TriggerValueTest.java | 22 ++++++++---- .../AbstractTxManagerTestService.java | 22 ++++++++---- .../transaction/JobTxManagerTest.java | 22 ++++++++---- .../transaction/JobTxManagerTestService.java | 22 ++++++++---- .../transaction/TxManagerTestBase.java | 22 ++++++++---- .../disjob/supervisor/util/AssertjTest.java | 22 ++++++++---- .../disjob/supervisor/util/CommonTest.java | 22 ++++++++---- .../supervisor/util/CronExpressionTest.java | 22 ++++++++---- .../disjob/supervisor/util/HashTest.java | 22 ++++++++---- .../supervisor/util/LambdaStreamTest.java | 22 ++++++++---- .../disjob/supervisor/util/NumbersTest.java | 22 ++++++++---- .../supervisor/util/ObjectUtilsTest.java | 22 ++++++++---- .../supervisor/util/ParallelStreamTest.java | 22 ++++++++---- .../util/ScheduledExecutorTest.java | 22 ++++++++---- .../supervisor/util/ScheduledTaskTest.java | 22 ++++++++---- .../supervisor/util/TimingWheelTest.java | 22 ++++++++---- .../disjob/supervisor/util/TreeMapTest.java | 22 ++++++++---- .../supervisor/util/TriggerTimeUtilsTest.java | 22 ++++++++---- .../test/EmbeddedMysqlAndRedisServer.java | 22 ++++++++---- .../cn/ponfee/disjob/test/db/DBUtils.java | 22 ++++++++---- .../test/db/EmbeddedH2DatabaseServer.java | 22 ++++++++---- .../test/db/EmbeddedMysqlServerMariaDB.java | 22 ++++++++---- .../db/EmbeddedMysqlServerTestcontainers.java | 22 ++++++++---- .../disjob/test/handler/AJobHandler.java | 22 ++++++++---- .../disjob/test/handler/BJobHandler.java | 22 ++++++++---- .../disjob/test/handler/CJobHandler.java | 22 ++++++++---- .../disjob/test/handler/DJobHandler.java | 22 ++++++++---- .../disjob/test/handler/EJobHandler.java | 22 ++++++++---- .../disjob/test/handler/NoopJobHandler.java | 22 ++++++++---- .../handler/PrimeAccumulateJobHandler.java | 22 ++++++++---- .../test/handler/PrimeCountJobHandler.java | 22 ++++++++---- .../test/handler/TestBroadcastJobHandler.java | 22 ++++++++---- .../test/redis/EmbeddedRedisServerKstyrc.java | 22 ++++++++---- .../EmbeddedRedisServerTestcontainers.java | 22 ++++++++---- .../cn/ponfee/disjob/test/util/Constants.java | 22 ++++++++---- .../cn/ponfee/disjob/test/util/Prime.java | 22 ++++++++---- .../test/util/PrimeCountJobHandlerTest.java | 22 ++++++++---- .../cn/ponfee/disjob/test/util/PrimeTest.java | 22 ++++++++---- .../ponfee/disjob/worker/WorkerStartup.java | 22 ++++++++---- .../disjob/worker/base/TaskTimingWheel.java | 22 ++++++++---- .../worker/base/TimingWheelRotator.java | 22 ++++++++---- .../worker/base/WorkerConfigurator.java | 22 ++++++++---- .../disjob/worker/base/WorkerThreadPool.java | 22 ++++++++---- .../worker/configuration/EnableWorker.java | 22 ++++++++---- .../worker/configuration/WorkerLifecycle.java | 22 ++++++++---- .../configuration/WorkerProperties.java | 22 ++++++++---- .../worker/provider/WorkerRpcProvider.java | 22 ++++++++---- 452 files changed, 6792 insertions(+), 3171 deletions(-) diff --git a/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/DisjobAdminConfiguration.java b/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/DisjobAdminConfiguration.java index d4994b5ca..555a4bb97 100644 --- a/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/DisjobAdminConfiguration.java +++ b/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/DisjobAdminConfiguration.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.admin; diff --git a/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/controller/DisjobInstanceController.java b/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/controller/DisjobInstanceController.java index 1fce53bfb..dc02c5006 100644 --- a/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/controller/DisjobInstanceController.java +++ b/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/controller/DisjobInstanceController.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.admin.controller; diff --git a/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/controller/DisjobJobController.java b/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/controller/DisjobJobController.java index cc49b47c2..13665693d 100644 --- a/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/controller/DisjobJobController.java +++ b/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/controller/DisjobJobController.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.admin.controller; diff --git a/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/controller/DisjobMgGroupController.java b/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/controller/DisjobMgGroupController.java index d765f54ee..ea2991524 100644 --- a/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/controller/DisjobMgGroupController.java +++ b/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/controller/DisjobMgGroupController.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.admin.controller; diff --git a/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/controller/DisjobMyGroupController.java b/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/controller/DisjobMyGroupController.java index f80ffe672..a337a6645 100644 --- a/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/controller/DisjobMyGroupController.java +++ b/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/controller/DisjobMyGroupController.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.admin.controller; diff --git a/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/controller/SupervisorInfoController.java b/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/controller/SupervisorInfoController.java index daf65287e..2cf89b200 100644 --- a/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/controller/SupervisorInfoController.java +++ b/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/controller/SupervisorInfoController.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.admin.controller; diff --git a/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/export/SchedJobExport.java b/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/export/SchedJobExport.java index 81a8034c8..25bc7b314 100644 --- a/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/export/SchedJobExport.java +++ b/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/export/SchedJobExport.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.admin.export; diff --git a/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/service/DisjobService.java b/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/service/DisjobService.java index de10107fa..0c1b8b61f 100644 --- a/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/service/DisjobService.java +++ b/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/service/DisjobService.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.admin.service; diff --git a/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/util/PageUtils.java b/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/util/PageUtils.java index b1d9fa819..0c83f6b52 100644 --- a/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/util/PageUtils.java +++ b/disjob-admin/ruoyi-disjob/src/main/java/cn/ponfee/disjob/admin/util/PageUtils.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.admin.util; diff --git a/disjob-admin/ruoyi-framework/src/main/java/com/ruoyi/framework/config/properties/SimpleJdbcProperties.java b/disjob-admin/ruoyi-framework/src/main/java/com/ruoyi/framework/config/properties/SimpleJdbcProperties.java index a2ee2ace3..562f74299 100644 --- a/disjob-admin/ruoyi-framework/src/main/java/com/ruoyi/framework/config/properties/SimpleJdbcProperties.java +++ b/disjob-admin/ruoyi-framework/src/main/java/com/ruoyi/framework/config/properties/SimpleJdbcProperties.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package com.ruoyi.framework.config.properties; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/ConsistentHash.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/ConsistentHash.java index 10e0f09e0..f3e6a8ce8 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/ConsistentHash.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/ConsistentHash.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.base; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/Destroyable.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/Destroyable.java index 583942045..137338036 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/Destroyable.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/Destroyable.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.base; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/IdGenerator.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/IdGenerator.java index 9006b24dd..cb86cc34d 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/IdGenerator.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/IdGenerator.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.base; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/Initializable.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/Initializable.java index ff0a48795..0f365ec02 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/Initializable.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/Initializable.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.base; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/IntValueDesc.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/IntValueDesc.java index d4ef38964..221164223 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/IntValueDesc.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/IntValueDesc.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.base; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/IntValueEnum.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/IntValueEnum.java index 3ab5e61d4..152034f85 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/IntValueEnum.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/IntValueEnum.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.base; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/LazyLoader.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/LazyLoader.java index 0e52ec12a..417b56435 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/LazyLoader.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/LazyLoader.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.base; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/NoArgMethodInvoker.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/NoArgMethodInvoker.java index ede4688d3..8d373f8ad 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/NoArgMethodInvoker.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/NoArgMethodInvoker.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.base; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/Null.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/Null.java index c511a28aa..d27483753 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/Null.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/Null.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.base; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/RetryInvocationHandler.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/RetryInvocationHandler.java index e1c3de247..27afe0ada 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/RetryInvocationHandler.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/RetryInvocationHandler.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.base; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/RetryTemplate.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/RetryTemplate.java index 510647fde..41def2cd2 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/RetryTemplate.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/RetryTemplate.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.base; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/SingletonClassConstraint.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/SingletonClassConstraint.java index 38fdf73a9..94de3a444 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/SingletonClassConstraint.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/SingletonClassConstraint.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.base; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/Startable.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/Startable.java index 75bcc015a..718b765a1 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/Startable.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/Startable.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.base; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/Symbol.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/Symbol.java index 20f440c78..d3cb589a1 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/Symbol.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/Symbol.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.base; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/TextTokenizer.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/TextTokenizer.java index c8137079a..63d3e2314 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/TextTokenizer.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/TextTokenizer.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.base; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/TimingWheel.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/TimingWheel.java index 094eedf17..03db36781 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/TimingWheel.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/TimingWheel.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.base; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/ToJsonString.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/ToJsonString.java index e27aab097..e72623fe4 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/ToJsonString.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/ToJsonString.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.base; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/ValueEnum.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/ValueEnum.java index 8378b7f7f..c8959723b 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/base/ValueEnum.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/base/ValueEnum.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.base; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/ArrayHashKey.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/ArrayHashKey.java index 4506d4c35..4195233c3 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/ArrayHashKey.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/ArrayHashKey.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.collect; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/Collects.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/Collects.java index 018352fc8..b3290d375 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/Collects.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/Collects.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.collect; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/DelegatedIntSpliterator.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/DelegatedIntSpliterator.java index e1b5b2d27..65efbe50b 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/DelegatedIntSpliterator.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/DelegatedIntSpliterator.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.collect; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/ImmutableArrayList.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/ImmutableArrayList.java index db753f34e..2d941488d 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/ImmutableArrayList.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/ImmutableArrayList.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.collect; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/ImmutableHashList.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/ImmutableHashList.java index 059f85c54..dfc9308f4 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/ImmutableHashList.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/ImmutableHashList.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.collect; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/PooledObjectProcessor.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/PooledObjectProcessor.java index 1751dd062..7e48c91cf 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/PooledObjectProcessor.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/PooledObjectProcessor.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.collect; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/RemovableTypedKeyValue.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/RemovableTypedKeyValue.java index f83f9bb2c..5dd788ad4 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/RemovableTypedKeyValue.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/RemovableTypedKeyValue.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.collect; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/RemovableTypedMap.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/RemovableTypedMap.java index 36da69f55..9507d5c19 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/RemovableTypedMap.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/RemovableTypedMap.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.collect; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/TypedKeyValue.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/TypedKeyValue.java index 795e3055e..da2181aa1 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/TypedKeyValue.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/TypedKeyValue.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.collect; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/TypedMap.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/TypedMap.java index 9149dd8db..325b012ba 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/TypedMap.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/collect/TypedMap.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.collect; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/AbstractHeartbeatThread.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/AbstractHeartbeatThread.java index 849f2f086..343cd87fd 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/AbstractHeartbeatThread.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/AbstractHeartbeatThread.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.concurrent; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/AsyncDelayedExecutor.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/AsyncDelayedExecutor.java index 59cdec85f..74939bf93 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/AsyncDelayedExecutor.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/AsyncDelayedExecutor.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.concurrent; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/DelayedData.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/DelayedData.java index 2a5983b82..4b570c816 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/DelayedData.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/DelayedData.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.concurrent; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/LoggedUncaughtExceptionHandler.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/LoggedUncaughtExceptionHandler.java index 486d49235..1af18c5e2 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/LoggedUncaughtExceptionHandler.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/LoggedUncaughtExceptionHandler.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.concurrent; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/LoopThread.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/LoopThread.java index 3436ed062..cac5aa0f6 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/LoopThread.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/LoopThread.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.concurrent; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/MultithreadExecutors.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/MultithreadExecutors.java index c0776ef6c..4a1566c5b 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/MultithreadExecutors.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/MultithreadExecutors.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.concurrent; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/NamedThreadFactory.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/NamedThreadFactory.java index 8801dff07..23ef83e41 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/NamedThreadFactory.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/NamedThreadFactory.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.concurrent; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/ThreadPoolExecutors.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/ThreadPoolExecutors.java index c9d64599f..364c0d32a 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/ThreadPoolExecutors.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/ThreadPoolExecutors.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.concurrent; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/Threads.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/Threads.java index 4fadab8ec..dbd2e90ef 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/Threads.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/concurrent/Threads.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.concurrent; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/dag/DAGEdge.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/dag/DAGEdge.java index 6043133fb..3a2a9920d 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/dag/DAGEdge.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/dag/DAGEdge.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.dag; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/dag/DAGExpressionParser.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/dag/DAGExpressionParser.java index ebf910abd..5002b2907 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/dag/DAGExpressionParser.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/dag/DAGExpressionParser.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.dag; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/dag/DAGNode.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/dag/DAGNode.java index 28ddd35ee..bb285473f 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/dag/DAGNode.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/dag/DAGNode.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.dag; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/date/DatePeriods.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/date/DatePeriods.java index e4f3df721..4fcf7fd8f 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/date/DatePeriods.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/date/DatePeriods.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.date; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/date/Dates.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/date/Dates.java index b29dce85a..cb34bbfb1 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/date/Dates.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/date/Dates.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.date; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/date/JacksonDate.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/date/JacksonDate.java index dadef72a1..f800413ef 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/date/JacksonDate.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/date/JacksonDate.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.date; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/date/JavaUtilDateFormat.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/date/JavaUtilDateFormat.java index 4a32628d0..45f61138c 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/date/JavaUtilDateFormat.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/date/JavaUtilDateFormat.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.date; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/date/LocalDateFormat.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/date/LocalDateFormat.java index 6a3a17c2f..c39f75b0f 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/date/LocalDateFormat.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/date/LocalDateFormat.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.date; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/date/LocalDateTimeFormat.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/date/LocalDateTimeFormat.java index 4399fca3b..13adf6f0f 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/date/LocalDateTimeFormat.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/date/LocalDateTimeFormat.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.date; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/exception/BaseException.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/exception/BaseException.java index 22db430d4..860c59201 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/exception/BaseException.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/exception/BaseException.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.exception; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/exception/BaseRuntimeException.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/exception/BaseRuntimeException.java index 1e593317b..ad21adbb4 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/exception/BaseRuntimeException.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/exception/BaseRuntimeException.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.exception; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/exception/Throwables.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/exception/Throwables.java index 53211c4df..543e26383 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/exception/Throwables.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/exception/Throwables.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.exception; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/lock/DoInDatabaseLocked.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/lock/DoInDatabaseLocked.java index 2f4597f6b..ed8ac96ef 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/lock/DoInDatabaseLocked.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/lock/DoInDatabaseLocked.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.lock; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/lock/DoInLocked.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/lock/DoInLocked.java index 7a1e1b887..cb0b7aa36 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/lock/DoInLocked.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/lock/DoInLocked.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.lock; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/lock/DoInRedisLocked.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/lock/DoInRedisLocked.java index c651e035e..b345857bf 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/lock/DoInRedisLocked.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/lock/DoInRedisLocked.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.lock; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/lock/RedisLock.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/lock/RedisLock.java index 2149b020a..7b88a0697 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/lock/RedisLock.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/lock/RedisLock.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.lock; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/lock/RedisLockFactory.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/lock/RedisLockFactory.java index 35e81e266..90cb63fc8 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/lock/RedisLockFactory.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/lock/RedisLockFactory.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.lock; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/model/BaseEntity.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/model/BaseEntity.java index 8f79f5910..d5fbbc047 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/model/BaseEntity.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/model/BaseEntity.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.model; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/model/CodeMsg.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/model/CodeMsg.java index 14fe7bda4..3d31d8ec7 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/model/CodeMsg.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/model/CodeMsg.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.model; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/model/PageRequest.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/model/PageRequest.java index 722432ffd..4387ebe0b 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/model/PageRequest.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/model/PageRequest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.model; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/model/PageResponse.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/model/PageResponse.java index b031275ac..cea007fa1 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/model/PageResponse.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/model/PageResponse.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.model; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/model/Result.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/model/Result.java index 19a47dad5..f1abbf9b6 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/model/Result.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/model/Result.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.model; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/BaseController.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/BaseController.java index e392a4abb..c577aaf41 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/BaseController.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/BaseController.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.spring; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/EnableJacksonDateConfigurer.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/EnableJacksonDateConfigurer.java index c4136456d..b1a8ef3ce 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/EnableJacksonDateConfigurer.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/EnableJacksonDateConfigurer.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.spring; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/JdbcTemplateWrapper.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/JdbcTemplateWrapper.java index 19a414444..0c4a283d3 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/JdbcTemplateWrapper.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/JdbcTemplateWrapper.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.spring; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/LocalizedMethodArgumentConfigurer.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/LocalizedMethodArgumentConfigurer.java index 5611c3f1a..1c0f5074e 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/LocalizedMethodArgumentConfigurer.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/LocalizedMethodArgumentConfigurer.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.spring; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/LocalizedMethodArgumentResolver.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/LocalizedMethodArgumentResolver.java index a6dc7ba8b..f6e8c4a95 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/LocalizedMethodArgumentResolver.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/LocalizedMethodArgumentResolver.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.spring; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/LocalizedMethodArgumentUtils.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/LocalizedMethodArgumentUtils.java index eed66e4ec..baf5364c2 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/LocalizedMethodArgumentUtils.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/LocalizedMethodArgumentUtils.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.spring; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/LocalizedMethodArguments.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/LocalizedMethodArguments.java index c6eb8b36e..edd65b6bf 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/LocalizedMethodArguments.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/LocalizedMethodArguments.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.spring; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/RedisKeyRenewal.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/RedisKeyRenewal.java index 25e3123c7..b320e50d3 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/RedisKeyRenewal.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/RedisKeyRenewal.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.spring; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/RedisTemplateUtils.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/RedisTemplateUtils.java index bb521530b..7ad8a64fa 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/RedisTemplateUtils.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/RedisTemplateUtils.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.spring; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/ResourceScanner.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/ResourceScanner.java index fe688e852..db8097c4d 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/ResourceScanner.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/ResourceScanner.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.spring; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/RestTemplateUtils.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/RestTemplateUtils.java index 7a30c10c3..80dd9d22e 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/RestTemplateUtils.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/RestTemplateUtils.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.spring; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/RpcController.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/RpcController.java index d1e6d5bf0..d03383d23 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/RpcController.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/RpcController.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.spring; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/SpringContextHolder.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/SpringContextHolder.java index 45af1c423..571bb5d98 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/SpringContextHolder.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/SpringContextHolder.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.spring; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/SpringUtils.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/SpringUtils.java index 472d3e3fe..1cfb9286b 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/SpringUtils.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/SpringUtils.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.spring; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/TransactionUtils.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/TransactionUtils.java index 3e76d29ba..74b5331d7 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/TransactionUtils.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/TransactionUtils.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.spring; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/YamlProperties.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/YamlProperties.java index 4b2f5772c..0d58d88e3 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/YamlProperties.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/YamlProperties.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.spring; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/YamlPropertySourceFactory.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/YamlPropertySourceFactory.java index 793ae314b..0f6fa6df1 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/YamlPropertySourceFactory.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/spring/YamlPropertySourceFactory.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.spring; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/BaseNode.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/BaseNode.java index 710ac09cb..67f9150a4 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/BaseNode.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/BaseNode.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.tree; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/FlatNode.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/FlatNode.java index 8ee42b089..aef36053f 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/FlatNode.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/FlatNode.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.tree; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/MapTreeTrait.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/MapTreeTrait.java index c01852d1d..a330f26bf 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/MapTreeTrait.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/MapTreeTrait.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.tree; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/NodeId.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/NodeId.java index db1907c39..d4eb0e3ca 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/NodeId.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/NodeId.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.tree; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/NodePath.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/NodePath.java index 13e4e3a7c..ec7fd7385 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/NodePath.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/NodePath.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.tree; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/PlainNode.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/PlainNode.java index 02a50f1e8..423d56d7f 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/PlainNode.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/PlainNode.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.tree; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/SiblingNodesComparator.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/SiblingNodesComparator.java index 53cf2b20c..59ff66948 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/SiblingNodesComparator.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/SiblingNodesComparator.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.tree; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/TreeNode.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/TreeNode.java index 67636d43f..e9151ed61 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/TreeNode.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/TreeNode.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.tree; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/TreeNodeBuilder.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/TreeNodeBuilder.java index fcaad8006..da24ba4b8 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/TreeNodeBuilder.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/TreeNodeBuilder.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.tree; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/TreeTrait.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/TreeTrait.java index b81faa66f..ccea12e6a 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/TreeTrait.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/TreeTrait.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.tree; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/print/BinaryTreePrinter.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/print/BinaryTreePrinter.java index 2366b7ee2..9f942f712 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/print/BinaryTreePrinter.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/print/BinaryTreePrinter.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.tree.print; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/print/MultiwayTreePrinter.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/print/MultiwayTreePrinter.java index 3677a0b7b..ef963323e 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/print/MultiwayTreePrinter.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/tree/print/MultiwayTreePrinter.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.tree.print; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/tuple/Tuple.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/tuple/Tuple.java index 8acb24fc9..bfd9c87f2 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/tuple/Tuple.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/tuple/Tuple.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.tuple; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/tuple/Tuple0.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/tuple/Tuple0.java index b0422a5e6..c8c1a3931 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/tuple/Tuple0.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/tuple/Tuple0.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.tuple; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/tuple/Tuple1.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/tuple/Tuple1.java index b6e28eb6c..053c6bb0e 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/tuple/Tuple1.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/tuple/Tuple1.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.tuple; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/tuple/Tuple2.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/tuple/Tuple2.java index 2bb05f6c0..0b8c41e43 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/tuple/Tuple2.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/tuple/Tuple2.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.tuple; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/tuple/Tuple3.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/tuple/Tuple3.java index f7e6b13c6..0440b252e 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/tuple/Tuple3.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/tuple/Tuple3.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.tuple; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/tuple/Tuple4.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/tuple/Tuple4.java index d5ad104e6..6e6f3e046 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/tuple/Tuple4.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/tuple/Tuple4.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.tuple; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Bytes.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Bytes.java index 67c064b27..26ee30a7b 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Bytes.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Bytes.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/ClassUtils.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/ClassUtils.java index edf04f324..812dc58f0 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/ClassUtils.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/ClassUtils.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Comparators.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Comparators.java index 39639b8d1..dfda646aa 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Comparators.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Comparators.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Enums.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Enums.java index 005b296cb..ce83c6fc5 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Enums.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Enums.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Fields.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Fields.java index 85bddee58..61e53517b 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Fields.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Fields.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Files.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Files.java index 626c82966..b4c02d3ea 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Files.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Files.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Functions.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Functions.java index 6e4d671b9..b119be27f 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Functions.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Functions.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/GenericUtils.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/GenericUtils.java index 14f28cfcb..0d48ad7fb 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/GenericUtils.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/GenericUtils.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/GroovyUtils.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/GroovyUtils.java index 9ead4a04d..ce340458f 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/GroovyUtils.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/GroovyUtils.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Jsons.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Jsons.java index be076240a..2b6a0e78c 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Jsons.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Jsons.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Maths.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Maths.java index 9732d6d24..4231f9d0c 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Maths.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Maths.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/MavenProjects.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/MavenProjects.java index 36b6e1d13..0fb01a54a 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/MavenProjects.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/MavenProjects.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/NetUtils.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/NetUtils.java index 138fa6d4f..f278fa552 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/NetUtils.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/NetUtils.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Numbers.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Numbers.java index a026cb4b0..3cad30597 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Numbers.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Numbers.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/ObjectUtils.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/ObjectUtils.java index c07e6fd68..b0031cdaa 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/ObjectUtils.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/ObjectUtils.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Predicates.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Predicates.java index d6b0aa4bb..d26021d25 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Predicates.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Predicates.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/PrimitiveTypes.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/PrimitiveTypes.java index 91a5ed9ce..309b22e98 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/PrimitiveTypes.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/PrimitiveTypes.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/ProcessUtils.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/ProcessUtils.java index a36f7ceca..0c860d69e 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/ProcessUtils.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/ProcessUtils.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/ProxyUtils.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/ProxyUtils.java index 395b38f00..8019910c4 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/ProxyUtils.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/ProxyUtils.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/SleepWaitUtils.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/SleepWaitUtils.java index 4f5b8cb47..f273454cd 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/SleepWaitUtils.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/SleepWaitUtils.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Strings.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Strings.java index 5ba5992f1..aa814cdac 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Strings.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/Strings.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/SystemUtils.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/SystemUtils.java index a6ca59932..e401294b0 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/SystemUtils.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/SystemUtils.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/URLCodes.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/URLCodes.java index 0a737ccbe..493a7a721 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/URLCodes.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/URLCodes.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/UuidUtils.java b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/UuidUtils.java index f8491a7f1..4308660f1 100644 --- a/disjob-common/src/main/java/cn/ponfee/disjob/common/util/UuidUtils.java +++ b/disjob-common/src/main/java/cn/ponfee/disjob/common/util/UuidUtils.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/test/java/cn/ponfee/disjob/common/base/ClassSingletonInstanceTest.java b/disjob-common/src/test/java/cn/ponfee/disjob/common/base/ClassSingletonInstanceTest.java index fd5a5506b..fb13fc4b2 100644 --- a/disjob-common/src/test/java/cn/ponfee/disjob/common/base/ClassSingletonInstanceTest.java +++ b/disjob-common/src/test/java/cn/ponfee/disjob/common/base/ClassSingletonInstanceTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.base; diff --git a/disjob-common/src/test/java/cn/ponfee/disjob/common/dag/DAGExpressionParserTest.java b/disjob-common/src/test/java/cn/ponfee/disjob/common/dag/DAGExpressionParserTest.java index 52f5f1d2a..b74701ea3 100644 --- a/disjob-common/src/test/java/cn/ponfee/disjob/common/dag/DAGExpressionParserTest.java +++ b/disjob-common/src/test/java/cn/ponfee/disjob/common/dag/DAGExpressionParserTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.dag; diff --git a/disjob-common/src/test/java/cn/ponfee/disjob/common/dag/DAGPrinter.java b/disjob-common/src/test/java/cn/ponfee/disjob/common/dag/DAGPrinter.java index 28cb301b5..5db9ce292 100644 --- a/disjob-common/src/test/java/cn/ponfee/disjob/common/dag/DAGPrinter.java +++ b/disjob-common/src/test/java/cn/ponfee/disjob/common/dag/DAGPrinter.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.dag; diff --git a/disjob-common/src/test/java/cn/ponfee/disjob/common/date/DatePeriodCalculatorTest.java b/disjob-common/src/test/java/cn/ponfee/disjob/common/date/DatePeriodCalculatorTest.java index 6767a1492..af6411c9a 100644 --- a/disjob-common/src/test/java/cn/ponfee/disjob/common/date/DatePeriodCalculatorTest.java +++ b/disjob-common/src/test/java/cn/ponfee/disjob/common/date/DatePeriodCalculatorTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.date; diff --git a/disjob-common/src/test/java/cn/ponfee/disjob/common/date/DatesTest.java b/disjob-common/src/test/java/cn/ponfee/disjob/common/date/DatesTest.java index 2e14a259b..b8ca24f37 100644 --- a/disjob-common/src/test/java/cn/ponfee/disjob/common/date/DatesTest.java +++ b/disjob-common/src/test/java/cn/ponfee/disjob/common/date/DatesTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.date; diff --git a/disjob-common/src/test/java/cn/ponfee/disjob/common/date/JavaUtilDateFormatTest.java b/disjob-common/src/test/java/cn/ponfee/disjob/common/date/JavaUtilDateFormatTest.java index e01fe53fe..d71cd26c0 100644 --- a/disjob-common/src/test/java/cn/ponfee/disjob/common/date/JavaUtilDateFormatTest.java +++ b/disjob-common/src/test/java/cn/ponfee/disjob/common/date/JavaUtilDateFormatTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.date; diff --git a/disjob-common/src/test/java/cn/ponfee/disjob/common/date/LocalDateTimeFormatTest.java b/disjob-common/src/test/java/cn/ponfee/disjob/common/date/LocalDateTimeFormatTest.java index 7052b72d4..ad5c13b28 100644 --- a/disjob-common/src/test/java/cn/ponfee/disjob/common/date/LocalDateTimeFormatTest.java +++ b/disjob-common/src/test/java/cn/ponfee/disjob/common/date/LocalDateTimeFormatTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.date; diff --git a/disjob-common/src/test/java/cn/ponfee/disjob/common/spring/ResourceScannerTest.java b/disjob-common/src/test/java/cn/ponfee/disjob/common/spring/ResourceScannerTest.java index acf87909b..d8de01814 100644 --- a/disjob-common/src/test/java/cn/ponfee/disjob/common/spring/ResourceScannerTest.java +++ b/disjob-common/src/test/java/cn/ponfee/disjob/common/spring/ResourceScannerTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.spring; @@ -35,6 +43,8 @@ public void test() { String file = "copy-right.txt"; Map map = new ResourceScanner(file).scan4text(); - assertThat(map.get("copy-right.txt")).contains(" http://www.ponfee.cn ").startsWith("/* __________ "); + assertThat(map.get(file)) + .startsWith("/*\n * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/)\n") + .contains("* https://www.apache.org/licenses/LICENSE-2.0\n"); } } diff --git a/disjob-common/src/test/java/cn/ponfee/disjob/common/util/BytesTest.java b/disjob-common/src/test/java/cn/ponfee/disjob/common/util/BytesTest.java index 762c69461..9c22fdceb 100644 --- a/disjob-common/src/test/java/cn/ponfee/disjob/common/util/BytesTest.java +++ b/disjob-common/src/test/java/cn/ponfee/disjob/common/util/BytesTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/test/java/cn/ponfee/disjob/common/util/CollectsTest.java b/disjob-common/src/test/java/cn/ponfee/disjob/common/util/CollectsTest.java index 8f45bbfbf..cae9cca5a 100644 --- a/disjob-common/src/test/java/cn/ponfee/disjob/common/util/CollectsTest.java +++ b/disjob-common/src/test/java/cn/ponfee/disjob/common/util/CollectsTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/test/java/cn/ponfee/disjob/common/util/CopyrightTest.java b/disjob-common/src/test/java/cn/ponfee/disjob/common/util/CopyrightTest.java index cbf92ca33..3a52fc402 100644 --- a/disjob-common/src/test/java/cn/ponfee/disjob/common/util/CopyrightTest.java +++ b/disjob-common/src/test/java/cn/ponfee/disjob/common/util/CopyrightTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; @@ -32,10 +40,10 @@ @Disabled public class CopyrightTest { - private static final String OLD_COPYRIGHT_KEYWORD = " Copyright (c) 2017-2023 Ponfee "; - private static final String NEW_COPYRIGHT_KEYWORD = " Copyright (c) 2017-2024 Ponfee "; + private static final String OLD_COPYRIGHT_KEYWORD = "\n * Copyright 2022-2023 Ponfee (http://www.ponfee.cn/)\n"; + private static final String NEW_COPYRIGHT_KEYWORD = "\n * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/)\n"; - private static final String BASE_DIR = MavenProjects.getProjectBaseDir(); + private static final String BASE_DIR = MavenProjects.getProjectBaseDir(); // + "/src/test/java/cn/ponfee/disjob/common/spring/a"; private static final String COPYRIGHT = ThrowingSupplier.doChecked( () -> IOUtils.resourceToString("copy-right.txt", UTF_8, CopyrightTest.class.getClassLoader()) ); @@ -48,16 +56,16 @@ public void upsertCopyright() { return; } try { - if (text.contains("** \\______ \\____ _____/ ____\\____ ____ " + OLD_COPYRIGHT_KEYWORD + " **")) { + if (text.contains(OLD_COPYRIGHT_KEYWORD)) { Writer writer = new FileWriter(file.getAbsolutePath()); IOUtils.write(COPYRIGHT, writer); - IOUtils.write(text.substring(83 * 7 + 1), writer); + IOUtils.write(text.substring(621), writer); writer.flush(); writer.close(); return; } - if (!text.contains("** \\______ \\____ _____/ ____\\____ ____ " + NEW_COPYRIGHT_KEYWORD)) { + if (!text.contains(NEW_COPYRIGHT_KEYWORD)) { Writer writer = new FileWriter(file.getAbsolutePath()); IOUtils.write(COPYRIGHT, writer); IOUtils.write(text, writer); diff --git a/disjob-common/src/test/java/cn/ponfee/disjob/common/util/FilesTest.java b/disjob-common/src/test/java/cn/ponfee/disjob/common/util/FilesTest.java index 37f43d131..2e1fb6b9c 100644 --- a/disjob-common/src/test/java/cn/ponfee/disjob/common/util/FilesTest.java +++ b/disjob-common/src/test/java/cn/ponfee/disjob/common/util/FilesTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/test/java/cn/ponfee/disjob/common/util/GroovyUtilsTest.java b/disjob-common/src/test/java/cn/ponfee/disjob/common/util/GroovyUtilsTest.java index e86dee8d3..b6c26242f 100644 --- a/disjob-common/src/test/java/cn/ponfee/disjob/common/util/GroovyUtilsTest.java +++ b/disjob-common/src/test/java/cn/ponfee/disjob/common/util/GroovyUtilsTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/test/java/cn/ponfee/disjob/common/util/HashFunctionTest.java b/disjob-common/src/test/java/cn/ponfee/disjob/common/util/HashFunctionTest.java index a22cd2a06..9241ef2d3 100644 --- a/disjob-common/src/test/java/cn/ponfee/disjob/common/util/HashFunctionTest.java +++ b/disjob-common/src/test/java/cn/ponfee/disjob/common/util/HashFunctionTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/test/java/cn/ponfee/disjob/common/util/JsonsTest.java b/disjob-common/src/test/java/cn/ponfee/disjob/common/util/JsonsTest.java index 00aca8581..0986a6c28 100644 --- a/disjob-common/src/test/java/cn/ponfee/disjob/common/util/JsonsTest.java +++ b/disjob-common/src/test/java/cn/ponfee/disjob/common/util/JsonsTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/test/java/cn/ponfee/disjob/common/util/MavenDependencyTest.java b/disjob-common/src/test/java/cn/ponfee/disjob/common/util/MavenDependencyTest.java index 94ff75bae..2fdcf612e 100644 --- a/disjob-common/src/test/java/cn/ponfee/disjob/common/util/MavenDependencyTest.java +++ b/disjob-common/src/test/java/cn/ponfee/disjob/common/util/MavenDependencyTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/test/java/cn/ponfee/disjob/common/util/ProxyUtilsTest.java b/disjob-common/src/test/java/cn/ponfee/disjob/common/util/ProxyUtilsTest.java index 5f19ec34d..c73fd2d30 100644 --- a/disjob-common/src/test/java/cn/ponfee/disjob/common/util/ProxyUtilsTest.java +++ b/disjob-common/src/test/java/cn/ponfee/disjob/common/util/ProxyUtilsTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/test/java/cn/ponfee/disjob/common/util/StringsTest.java b/disjob-common/src/test/java/cn/ponfee/disjob/common/util/StringsTest.java index e00d93f55..d442a3cc1 100644 --- a/disjob-common/src/test/java/cn/ponfee/disjob/common/util/StringsTest.java +++ b/disjob-common/src/test/java/cn/ponfee/disjob/common/util/StringsTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-common/src/test/java/cn/ponfee/disjob/common/util/TextTokenizerTest.java b/disjob-common/src/test/java/cn/ponfee/disjob/common/util/TextTokenizerTest.java index 90bd31848..95c91691a 100644 --- a/disjob-common/src/test/java/cn/ponfee/disjob/common/util/TextTokenizerTest.java +++ b/disjob-common/src/test/java/cn/ponfee/disjob/common/util/TextTokenizerTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/base/HttpProperties.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/base/HttpProperties.java index 5cc1701de..4082a4b87 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/base/HttpProperties.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/base/HttpProperties.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.base; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/base/JobCodeMsg.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/base/JobCodeMsg.java index cf4545a27..1f5c50746 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/base/JobCodeMsg.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/base/JobCodeMsg.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.base; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/base/JobConstants.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/base/JobConstants.java index f674a2a2d..b1095893d 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/base/JobConstants.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/base/JobConstants.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.base; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/base/RetryProperties.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/base/RetryProperties.java index 715c17aab..8bd094f99 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/base/RetryProperties.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/base/RetryProperties.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.base; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/base/Server.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/base/Server.java index d3c30365d..1fa3742b0 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/base/Server.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/base/Server.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.base; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/base/Supervisor.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/base/Supervisor.java index c011eabbd..aeb2df8bc 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/base/Supervisor.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/base/Supervisor.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.base; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/base/SupervisorMetrics.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/base/SupervisorMetrics.java index 166355e44..c327c886c 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/base/SupervisorMetrics.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/base/SupervisorMetrics.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.base; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/base/SupervisorRpcService.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/base/SupervisorRpcService.java index 6d760c943..07ceeb1d4 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/base/SupervisorRpcService.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/base/SupervisorRpcService.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.base; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/base/Tokens.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/base/Tokens.java index 842c4fc25..bf0bf8919 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/base/Tokens.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/base/Tokens.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.base; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/base/Worker.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/base/Worker.java index 8bb185aa5..d891acfcb 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/base/Worker.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/base/Worker.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.base; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/base/WorkerMetrics.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/base/WorkerMetrics.java index 66a589c78..acf1e147d 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/base/WorkerMetrics.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/base/WorkerMetrics.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.base; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/base/WorkerRpcService.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/base/WorkerRpcService.java index 3a966b061..ba557bfcf 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/base/WorkerRpcService.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/base/WorkerRpcService.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.base; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/CollidedStrategy.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/CollidedStrategy.java index f03b581d5..1e443ed6e 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/CollidedStrategy.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/CollidedStrategy.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.enums; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/ExecuteState.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/ExecuteState.java index 826024191..f18cb1192 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/ExecuteState.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/ExecuteState.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.enums; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/JobState.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/JobState.java index 795cc7e16..8c0e25089 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/JobState.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/JobState.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.enums; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/JobType.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/JobType.java index bb756ce48..374a9a2c6 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/JobType.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/JobType.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.enums; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/MisfireStrategy.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/MisfireStrategy.java index ac0f33a12..d1063378c 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/MisfireStrategy.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/MisfireStrategy.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.enums; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/Operation.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/Operation.java index b3b330038..f356230a8 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/Operation.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/Operation.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.enums; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/RetryType.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/RetryType.java index 2d8c37e19..a12bf9ea9 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/RetryType.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/RetryType.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.enums; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/RouteStrategy.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/RouteStrategy.java index d73176744..507ead28c 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/RouteStrategy.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/RouteStrategy.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.enums; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/RunState.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/RunState.java index 2226d9c13..4ccaaf886 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/RunState.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/RunState.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.enums; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/RunType.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/RunType.java index 5d0d3d7b0..e3a827a85 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/RunType.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/RunType.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.enums; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/TriggerType.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/TriggerType.java index 0ab0964cc..dadf31992 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/TriggerType.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/enums/TriggerType.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.enums; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/event/TaskDispatchFailedEvent.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/event/TaskDispatchFailedEvent.java index 35b77b88a..95fc9f2f9 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/event/TaskDispatchFailedEvent.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/event/TaskDispatchFailedEvent.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.event; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/AuthenticationException.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/AuthenticationException.java index 26453bbac..3edc3b226 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/AuthenticationException.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/AuthenticationException.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.exception; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/CancelTaskException.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/CancelTaskException.java index 5da6134e8..bec90bffa 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/CancelTaskException.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/CancelTaskException.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.exception; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/GroupNotFoundException.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/GroupNotFoundException.java index 33856b31f..a9412827a 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/GroupNotFoundException.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/GroupNotFoundException.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.exception; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/JobException.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/JobException.java index 991d8d79a..3b137da83 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/JobException.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/JobException.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.exception; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/JobRuntimeException.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/JobRuntimeException.java index 96ff7050c..db1ae098d 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/JobRuntimeException.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/JobRuntimeException.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.exception; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/KeyExistsException.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/KeyExistsException.java index 8c84cb29b..ff40e6d3d 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/KeyExistsException.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/KeyExistsException.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.exception; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/KeyNotExistsException.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/KeyNotExistsException.java index ef99910e9..ef9d532b8 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/KeyNotExistsException.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/KeyNotExistsException.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.exception; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/PauseTaskException.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/PauseTaskException.java index be624aba2..508207870 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/PauseTaskException.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/exception/PauseTaskException.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.exception; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/BroadcastJobHandler.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/BroadcastJobHandler.java index 83eaac389..66a79ad92 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/BroadcastJobHandler.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/BroadcastJobHandler.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.handle; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/ExecuteResult.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/ExecuteResult.java index 3aadd5224..195bbacc1 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/ExecuteResult.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/ExecuteResult.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.handle; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/JobHandler.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/JobHandler.java index 84e327143..3ac6f28c5 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/JobHandler.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/JobHandler.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.handle; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/JobHandlerUtils.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/JobHandlerUtils.java index c1f2d6105..9c19b7aed 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/JobHandlerUtils.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/JobHandlerUtils.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.handle; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/JobSplitter.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/JobSplitter.java index bbc9a2328..e9692e355 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/JobSplitter.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/JobSplitter.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.handle; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/Savepoint.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/Savepoint.java index bcfd2dc08..a54138d7d 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/Savepoint.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/Savepoint.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.handle; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/SplitTask.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/SplitTask.java index 53be32041..b4b46c38d 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/SplitTask.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/SplitTask.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.handle; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/TaskExecutor.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/TaskExecutor.java index 9b0f2852c..c66b7acff 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/TaskExecutor.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/TaskExecutor.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.handle; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/execution/AbstractExecutionTask.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/execution/AbstractExecutionTask.java index c1cc18d3d..5f59637af 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/execution/AbstractExecutionTask.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/execution/AbstractExecutionTask.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.handle.execution; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/execution/ExecutedTask.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/execution/ExecutedTask.java index 1d2aed39b..47c6bc06a 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/execution/ExecutedTask.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/execution/ExecutedTask.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.handle.execution; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/execution/ExecutingTask.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/execution/ExecutingTask.java index 91d4c69d1..4c8040043 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/execution/ExecutingTask.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/execution/ExecutingTask.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.handle.execution; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/execution/ExecutionTaskConverter.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/execution/ExecutionTaskConverter.java index a76f20a17..40548c18d 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/execution/ExecutionTaskConverter.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/execution/ExecutionTaskConverter.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.handle.execution; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/execution/WorkflowPredecessorNode.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/execution/WorkflowPredecessorNode.java index 4a5bf535e..6ec8a17a9 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/execution/WorkflowPredecessorNode.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/execution/WorkflowPredecessorNode.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.handle.execution; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/impl/CommandJobHandler.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/impl/CommandJobHandler.java index d4c5477f4..a283120f6 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/impl/CommandJobHandler.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/impl/CommandJobHandler.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.handle.impl; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/impl/GroovyJobHandler.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/impl/GroovyJobHandler.java index 6d0b34732..b4e2a8d3a 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/impl/GroovyJobHandler.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/impl/GroovyJobHandler.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.handle.impl; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/impl/HttpJobHandler.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/impl/HttpJobHandler.java index 164f82844..08895b8bd 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/impl/HttpJobHandler.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/impl/HttpJobHandler.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.handle.impl; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/impl/ScriptJobHandler.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/impl/ScriptJobHandler.java index bec130cd0..535a4dd7d 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/impl/ScriptJobHandler.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/handle/impl/ScriptJobHandler.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.handle.impl; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/model/InstanceAttach.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/model/InstanceAttach.java index e8b417e87..2677117f3 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/model/InstanceAttach.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/model/InstanceAttach.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.model; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/model/PeriodTriggerValue.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/model/PeriodTriggerValue.java index d9765f2ce..76e123476 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/model/PeriodTriggerValue.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/model/PeriodTriggerValue.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.model; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/model/SchedDepend.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/model/SchedDepend.java index a9898388c..75a8fcea4 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/model/SchedDepend.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/model/SchedDepend.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.model; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/model/SchedGroup.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/model/SchedGroup.java index b2251cac0..62b1093f3 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/model/SchedGroup.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/model/SchedGroup.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.model; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/model/SchedInstance.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/model/SchedInstance.java index 65a6f5238..6495ab74c 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/model/SchedInstance.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/model/SchedInstance.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.model; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/model/SchedJob.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/model/SchedJob.java index dfc9d991f..8bfb34009 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/model/SchedJob.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/model/SchedJob.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.model; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/model/SchedTask.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/model/SchedTask.java index f451280b6..1188f03bb 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/model/SchedTask.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/model/SchedTask.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.model; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/model/SchedWorkflow.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/model/SchedWorkflow.java index aa1548efd..183519168 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/model/SchedWorkflow.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/model/SchedWorkflow.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.model; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/model/TokenType.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/model/TokenType.java index f44ab88a0..6a42b91db 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/model/TokenType.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/model/TokenType.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.model; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/param/supervisor/EventParam.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/param/supervisor/EventParam.java index e1d25002e..1ff607d11 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/param/supervisor/EventParam.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/param/supervisor/EventParam.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.param.supervisor; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/param/supervisor/StartTaskParam.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/param/supervisor/StartTaskParam.java index dcb18fb82..9b3c510aa 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/param/supervisor/StartTaskParam.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/param/supervisor/StartTaskParam.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.param.supervisor; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/param/supervisor/TerminateTaskParam.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/param/supervisor/TerminateTaskParam.java index 0df70a4fd..e0afab726 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/param/supervisor/TerminateTaskParam.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/param/supervisor/TerminateTaskParam.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.param.supervisor; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/param/supervisor/UpdateTaskWorkerParam.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/param/supervisor/UpdateTaskWorkerParam.java index 576748826..47ee95b1b 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/param/supervisor/UpdateTaskWorkerParam.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/param/supervisor/UpdateTaskWorkerParam.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.param.supervisor; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/param/worker/AuthenticationParam.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/param/worker/AuthenticationParam.java index 3a8b46466..55d88a407 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/param/worker/AuthenticationParam.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/param/worker/AuthenticationParam.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.param.worker; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/param/worker/ConfigureWorkerParam.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/param/worker/ConfigureWorkerParam.java index c5f47650f..793b847d9 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/param/worker/ConfigureWorkerParam.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/param/worker/ConfigureWorkerParam.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.param.worker; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/param/worker/GetMetricsParam.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/param/worker/GetMetricsParam.java index 51e006e5e..53ff9b69e 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/param/worker/GetMetricsParam.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/param/worker/GetMetricsParam.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.param.worker; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/param/worker/JobHandlerParam.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/param/worker/JobHandlerParam.java index f705a5a30..5d3274887 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/param/worker/JobHandlerParam.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/param/worker/JobHandlerParam.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.param.worker; diff --git a/disjob-core/src/main/java/cn/ponfee/disjob/core/util/JobUtils.java b/disjob-core/src/main/java/cn/ponfee/disjob/core/util/JobUtils.java index 4fd8b37a2..c771f6279 100644 --- a/disjob-core/src/main/java/cn/ponfee/disjob/core/util/JobUtils.java +++ b/disjob-core/src/main/java/cn/ponfee/disjob/core/util/JobUtils.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.util; diff --git a/disjob-core/src/test/java/cn/ponfee/disjob/core/base/ServerTest.java b/disjob-core/src/test/java/cn/ponfee/disjob/core/base/ServerTest.java index 428f8733f..465879890 100644 --- a/disjob-core/src/test/java/cn/ponfee/disjob/core/base/ServerTest.java +++ b/disjob-core/src/test/java/cn/ponfee/disjob/core/base/ServerTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.base; diff --git a/disjob-core/src/test/java/cn/ponfee/disjob/core/base/TokensTest.java b/disjob-core/src/test/java/cn/ponfee/disjob/core/base/TokensTest.java index 7ed52cde1..4ad5eb011 100644 --- a/disjob-core/src/test/java/cn/ponfee/disjob/core/base/TokensTest.java +++ b/disjob-core/src/test/java/cn/ponfee/disjob/core/base/TokensTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.base; diff --git a/disjob-core/src/test/java/cn/ponfee/disjob/core/enums/ExecuteStateTest.java b/disjob-core/src/test/java/cn/ponfee/disjob/core/enums/ExecuteStateTest.java index ee659d68d..70f6b3237 100644 --- a/disjob-core/src/test/java/cn/ponfee/disjob/core/enums/ExecuteStateTest.java +++ b/disjob-core/src/test/java/cn/ponfee/disjob/core/enums/ExecuteStateTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.enums; diff --git a/disjob-core/src/test/java/cn/ponfee/disjob/core/handle/CommandJobHandlerTest.java b/disjob-core/src/test/java/cn/ponfee/disjob/core/handle/CommandJobHandlerTest.java index a6875592b..7f913237a 100644 --- a/disjob-core/src/test/java/cn/ponfee/disjob/core/handle/CommandJobHandlerTest.java +++ b/disjob-core/src/test/java/cn/ponfee/disjob/core/handle/CommandJobHandlerTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.handle; diff --git a/disjob-core/src/test/java/cn/ponfee/disjob/core/handle/EnumTest.java b/disjob-core/src/test/java/cn/ponfee/disjob/core/handle/EnumTest.java index 92e6ac3bb..a10f99fb2 100644 --- a/disjob-core/src/test/java/cn/ponfee/disjob/core/handle/EnumTest.java +++ b/disjob-core/src/test/java/cn/ponfee/disjob/core/handle/EnumTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.handle; diff --git a/disjob-core/src/test/java/cn/ponfee/disjob/core/handle/ExecuteResultTest.java b/disjob-core/src/test/java/cn/ponfee/disjob/core/handle/ExecuteResultTest.java index c0a761963..52439ae12 100644 --- a/disjob-core/src/test/java/cn/ponfee/disjob/core/handle/ExecuteResultTest.java +++ b/disjob-core/src/test/java/cn/ponfee/disjob/core/handle/ExecuteResultTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.handle; diff --git a/disjob-core/src/test/java/cn/ponfee/disjob/core/handle/HttpJobHandlerTest.java b/disjob-core/src/test/java/cn/ponfee/disjob/core/handle/HttpJobHandlerTest.java index 9842032d5..d272f8ec0 100644 --- a/disjob-core/src/test/java/cn/ponfee/disjob/core/handle/HttpJobHandlerTest.java +++ b/disjob-core/src/test/java/cn/ponfee/disjob/core/handle/HttpJobHandlerTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.handle; diff --git a/disjob-core/src/test/java/cn/ponfee/disjob/core/handle/ScriptJobHandlerTest.java b/disjob-core/src/test/java/cn/ponfee/disjob/core/handle/ScriptJobHandlerTest.java index b2b7ccf10..0a01e7bce 100644 --- a/disjob-core/src/test/java/cn/ponfee/disjob/core/handle/ScriptJobHandlerTest.java +++ b/disjob-core/src/test/java/cn/ponfee/disjob/core/handle/ScriptJobHandlerTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.handle; diff --git a/disjob-core/src/test/java/cn/ponfee/disjob/core/handle/execution/ExecutionTaskConverterTest.java b/disjob-core/src/test/java/cn/ponfee/disjob/core/handle/execution/ExecutionTaskConverterTest.java index af0f99b82..c2818546b 100644 --- a/disjob-core/src/test/java/cn/ponfee/disjob/core/handle/execution/ExecutionTaskConverterTest.java +++ b/disjob-core/src/test/java/cn/ponfee/disjob/core/handle/execution/ExecutionTaskConverterTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.core.handle.execution; diff --git a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/DispatchTaskParam.java b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/DispatchTaskParam.java index 3a4806f43..9798dd0e7 100644 --- a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/DispatchTaskParam.java +++ b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/DispatchTaskParam.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.dispatch; diff --git a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/ExecuteTaskParam.java b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/ExecuteTaskParam.java index db7114c66..12553467d 100644 --- a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/ExecuteTaskParam.java +++ b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/ExecuteTaskParam.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.dispatch; diff --git a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/TaskDispatchException.java b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/TaskDispatchException.java index 368cd34cd..6c3540921 100644 --- a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/TaskDispatchException.java +++ b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/TaskDispatchException.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.dispatch; diff --git a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/TaskDispatcher.java b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/TaskDispatcher.java index aab5e07f1..caa59bdfb 100644 --- a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/TaskDispatcher.java +++ b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/TaskDispatcher.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.dispatch; diff --git a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/TaskReceiver.java b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/TaskReceiver.java index b9855663a..9a501bf45 100644 --- a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/TaskReceiver.java +++ b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/TaskReceiver.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.dispatch; diff --git a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/configuration/BaseTaskDispatchingAutoConfiguration.java b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/configuration/BaseTaskDispatchingAutoConfiguration.java index 45f7a81cc..230f6edb6 100644 --- a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/configuration/BaseTaskDispatchingAutoConfiguration.java +++ b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/configuration/BaseTaskDispatchingAutoConfiguration.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.dispatch.configuration; diff --git a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/BroadcastExecutionRouter.java b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/BroadcastExecutionRouter.java index ba6d1cc74..ac04991b5 100644 --- a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/BroadcastExecutionRouter.java +++ b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/BroadcastExecutionRouter.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.dispatch.route; diff --git a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/ConsistentHashExecutionRouter.java b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/ConsistentHashExecutionRouter.java index 4796d5e88..dd24833c5 100644 --- a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/ConsistentHashExecutionRouter.java +++ b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/ConsistentHashExecutionRouter.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.dispatch.route; diff --git a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/ExecutionRouter.java b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/ExecutionRouter.java index 087b0647b..c14cb5eda 100644 --- a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/ExecutionRouter.java +++ b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/ExecutionRouter.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.dispatch.route; diff --git a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/ExecutionRouterException.java b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/ExecutionRouterException.java index 0610a94eb..92626c57f 100644 --- a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/ExecutionRouterException.java +++ b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/ExecutionRouterException.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.dispatch.route; diff --git a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/ExecutionRouterRegistrar.java b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/ExecutionRouterRegistrar.java index dbe6480f1..25a6365d1 100644 --- a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/ExecutionRouterRegistrar.java +++ b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/ExecutionRouterRegistrar.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.dispatch.route; diff --git a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/LocalPriorityExecutionRouter.java b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/LocalPriorityExecutionRouter.java index 2a807a950..44ad1ed4a 100644 --- a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/LocalPriorityExecutionRouter.java +++ b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/LocalPriorityExecutionRouter.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.dispatch.route; diff --git a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/RandomExecutionRouter.java b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/RandomExecutionRouter.java index df654994a..cf82c3f5a 100644 --- a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/RandomExecutionRouter.java +++ b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/RandomExecutionRouter.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.dispatch.route; diff --git a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/RoundRobinExecutionRouter.java b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/RoundRobinExecutionRouter.java index 36683bca9..66d822a8a 100644 --- a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/RoundRobinExecutionRouter.java +++ b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/RoundRobinExecutionRouter.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.dispatch.route; diff --git a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/SimpleHashExecutionRouter.java b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/SimpleHashExecutionRouter.java index 376f8c421..a62d9c1d2 100644 --- a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/SimpleHashExecutionRouter.java +++ b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/SimpleHashExecutionRouter.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.dispatch.route; diff --git a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/count/AtomicCounter.java b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/count/AtomicCounter.java index cd24d3eeb..75cf23000 100644 --- a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/count/AtomicCounter.java +++ b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/count/AtomicCounter.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.dispatch.route.count; diff --git a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/count/JdkAtomicCounter.java b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/count/JdkAtomicCounter.java index 306b4579f..5c86780a6 100644 --- a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/count/JdkAtomicCounter.java +++ b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/count/JdkAtomicCounter.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.dispatch.route.count; diff --git a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/count/RedisAtomicCounter.java b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/count/RedisAtomicCounter.java index 5b5c43752..a788912c3 100644 --- a/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/count/RedisAtomicCounter.java +++ b/disjob-dispatch/disjob-dispatch-api/src/main/java/cn/ponfee/disjob/dispatch/route/count/RedisAtomicCounter.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.dispatch.route.count; diff --git a/disjob-dispatch/disjob-dispatch-api/src/test/java/cn/ponfee/disjob/dispatch/route/ConsistentHashExecutionRouterTest.java b/disjob-dispatch/disjob-dispatch-api/src/test/java/cn/ponfee/disjob/dispatch/route/ConsistentHashExecutionRouterTest.java index da174ddf9..77df1cea6 100644 --- a/disjob-dispatch/disjob-dispatch-api/src/test/java/cn/ponfee/disjob/dispatch/route/ConsistentHashExecutionRouterTest.java +++ b/disjob-dispatch/disjob-dispatch-api/src/test/java/cn/ponfee/disjob/dispatch/route/ConsistentHashExecutionRouterTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.dispatch.route; diff --git a/disjob-dispatch/disjob-dispatch-http/src/main/java/cn/ponfee/disjob/dispatch/http/HttpTaskDispatcher.java b/disjob-dispatch/disjob-dispatch-http/src/main/java/cn/ponfee/disjob/dispatch/http/HttpTaskDispatcher.java index d296282ec..9f39e7ff6 100644 --- a/disjob-dispatch/disjob-dispatch-http/src/main/java/cn/ponfee/disjob/dispatch/http/HttpTaskDispatcher.java +++ b/disjob-dispatch/disjob-dispatch-http/src/main/java/cn/ponfee/disjob/dispatch/http/HttpTaskDispatcher.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.dispatch.http; diff --git a/disjob-dispatch/disjob-dispatch-http/src/main/java/cn/ponfee/disjob/dispatch/http/HttpTaskReceiver.java b/disjob-dispatch/disjob-dispatch-http/src/main/java/cn/ponfee/disjob/dispatch/http/HttpTaskReceiver.java index a7955f068..99beb13f7 100644 --- a/disjob-dispatch/disjob-dispatch-http/src/main/java/cn/ponfee/disjob/dispatch/http/HttpTaskReceiver.java +++ b/disjob-dispatch/disjob-dispatch-http/src/main/java/cn/ponfee/disjob/dispatch/http/HttpTaskReceiver.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.dispatch.http; diff --git a/disjob-dispatch/disjob-dispatch-http/src/main/java/cn/ponfee/disjob/dispatch/http/HttpTaskReceiverService.java b/disjob-dispatch/disjob-dispatch-http/src/main/java/cn/ponfee/disjob/dispatch/http/HttpTaskReceiverService.java index ab688dba8..de8a54b33 100644 --- a/disjob-dispatch/disjob-dispatch-http/src/main/java/cn/ponfee/disjob/dispatch/http/HttpTaskReceiverService.java +++ b/disjob-dispatch/disjob-dispatch-http/src/main/java/cn/ponfee/disjob/dispatch/http/HttpTaskReceiverService.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.dispatch.http; diff --git a/disjob-dispatch/disjob-dispatch-http/src/main/java/cn/ponfee/disjob/dispatch/http/configuration/HttpTaskDispatchingAutoConfiguration.java b/disjob-dispatch/disjob-dispatch-http/src/main/java/cn/ponfee/disjob/dispatch/http/configuration/HttpTaskDispatchingAutoConfiguration.java index 3da147d01..b666ef09a 100644 --- a/disjob-dispatch/disjob-dispatch-http/src/main/java/cn/ponfee/disjob/dispatch/http/configuration/HttpTaskDispatchingAutoConfiguration.java +++ b/disjob-dispatch/disjob-dispatch-http/src/main/java/cn/ponfee/disjob/dispatch/http/configuration/HttpTaskDispatchingAutoConfiguration.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.dispatch.http.configuration; diff --git a/disjob-dispatch/disjob-dispatch-redis/src/main/java/cn/ponfee/disjob/dispatch/redis/RedisTaskDispatcher.java b/disjob-dispatch/disjob-dispatch-redis/src/main/java/cn/ponfee/disjob/dispatch/redis/RedisTaskDispatcher.java index 9f73f3264..5d83faf19 100644 --- a/disjob-dispatch/disjob-dispatch-redis/src/main/java/cn/ponfee/disjob/dispatch/redis/RedisTaskDispatcher.java +++ b/disjob-dispatch/disjob-dispatch-redis/src/main/java/cn/ponfee/disjob/dispatch/redis/RedisTaskDispatcher.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.dispatch.redis; diff --git a/disjob-dispatch/disjob-dispatch-redis/src/main/java/cn/ponfee/disjob/dispatch/redis/RedisTaskDispatchingUtils.java b/disjob-dispatch/disjob-dispatch-redis/src/main/java/cn/ponfee/disjob/dispatch/redis/RedisTaskDispatchingUtils.java index 004fbd5cc..ea4a745a9 100644 --- a/disjob-dispatch/disjob-dispatch-redis/src/main/java/cn/ponfee/disjob/dispatch/redis/RedisTaskDispatchingUtils.java +++ b/disjob-dispatch/disjob-dispatch-redis/src/main/java/cn/ponfee/disjob/dispatch/redis/RedisTaskDispatchingUtils.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.dispatch.redis; diff --git a/disjob-dispatch/disjob-dispatch-redis/src/main/java/cn/ponfee/disjob/dispatch/redis/RedisTaskReceiver.java b/disjob-dispatch/disjob-dispatch-redis/src/main/java/cn/ponfee/disjob/dispatch/redis/RedisTaskReceiver.java index cb9684ffb..f9035b1f7 100644 --- a/disjob-dispatch/disjob-dispatch-redis/src/main/java/cn/ponfee/disjob/dispatch/redis/RedisTaskReceiver.java +++ b/disjob-dispatch/disjob-dispatch-redis/src/main/java/cn/ponfee/disjob/dispatch/redis/RedisTaskReceiver.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.dispatch.redis; diff --git a/disjob-dispatch/disjob-dispatch-redis/src/main/java/cn/ponfee/disjob/dispatch/redis/configuration/RedisTaskDispatchingAutoConfiguration.java b/disjob-dispatch/disjob-dispatch-redis/src/main/java/cn/ponfee/disjob/dispatch/redis/configuration/RedisTaskDispatchingAutoConfiguration.java index a403c894b..4d39040e9 100644 --- a/disjob-dispatch/disjob-dispatch-redis/src/main/java/cn/ponfee/disjob/dispatch/redis/configuration/RedisTaskDispatchingAutoConfiguration.java +++ b/disjob-dispatch/disjob-dispatch-redis/src/main/java/cn/ponfee/disjob/dispatch/redis/configuration/RedisTaskDispatchingAutoConfiguration.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.dispatch.redis.configuration; diff --git a/disjob-id/src/main/java/cn/ponfee/disjob/id/snowflake/ClockMovedBackwardsException.java b/disjob-id/src/main/java/cn/ponfee/disjob/id/snowflake/ClockMovedBackwardsException.java index 04da2b90c..ac6f305c6 100644 --- a/disjob-id/src/main/java/cn/ponfee/disjob/id/snowflake/ClockMovedBackwardsException.java +++ b/disjob-id/src/main/java/cn/ponfee/disjob/id/snowflake/ClockMovedBackwardsException.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.id.snowflake; diff --git a/disjob-id/src/main/java/cn/ponfee/disjob/id/snowflake/Snowflake.java b/disjob-id/src/main/java/cn/ponfee/disjob/id/snowflake/Snowflake.java index 224efd4e6..92ff5ffac 100644 --- a/disjob-id/src/main/java/cn/ponfee/disjob/id/snowflake/Snowflake.java +++ b/disjob-id/src/main/java/cn/ponfee/disjob/id/snowflake/Snowflake.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.id.snowflake; diff --git a/disjob-id/src/main/java/cn/ponfee/disjob/id/snowflake/db/DbDistributedSnowflake.java b/disjob-id/src/main/java/cn/ponfee/disjob/id/snowflake/db/DbDistributedSnowflake.java index 5c2d89a62..0d14b8c88 100644 --- a/disjob-id/src/main/java/cn/ponfee/disjob/id/snowflake/db/DbDistributedSnowflake.java +++ b/disjob-id/src/main/java/cn/ponfee/disjob/id/snowflake/db/DbDistributedSnowflake.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.id.snowflake.db; diff --git a/disjob-id/src/main/java/cn/ponfee/disjob/id/snowflake/db/DbSnowflakeWorker.java b/disjob-id/src/main/java/cn/ponfee/disjob/id/snowflake/db/DbSnowflakeWorker.java index c56eb703b..5ceb5e53e 100644 --- a/disjob-id/src/main/java/cn/ponfee/disjob/id/snowflake/db/DbSnowflakeWorker.java +++ b/disjob-id/src/main/java/cn/ponfee/disjob/id/snowflake/db/DbSnowflakeWorker.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.id.snowflake.db; diff --git a/disjob-id/src/main/java/cn/ponfee/disjob/id/snowflake/zk/ZkConfig.java b/disjob-id/src/main/java/cn/ponfee/disjob/id/snowflake/zk/ZkConfig.java index 5bf1b3f08..f177daaf3 100644 --- a/disjob-id/src/main/java/cn/ponfee/disjob/id/snowflake/zk/ZkConfig.java +++ b/disjob-id/src/main/java/cn/ponfee/disjob/id/snowflake/zk/ZkConfig.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.id.snowflake.zk; diff --git a/disjob-id/src/main/java/cn/ponfee/disjob/id/snowflake/zk/ZkDistributedSnowflake.java b/disjob-id/src/main/java/cn/ponfee/disjob/id/snowflake/zk/ZkDistributedSnowflake.java index 905d48543..fd34a2dec 100644 --- a/disjob-id/src/main/java/cn/ponfee/disjob/id/snowflake/zk/ZkDistributedSnowflake.java +++ b/disjob-id/src/main/java/cn/ponfee/disjob/id/snowflake/zk/ZkDistributedSnowflake.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.id.snowflake.zk; diff --git a/disjob-id/src/test/java/cn/ponfee/disjob/id/snowflake/DbDistributedSnowflakeTest.java b/disjob-id/src/test/java/cn/ponfee/disjob/id/snowflake/DbDistributedSnowflakeTest.java index bd8fb832a..eae97818d 100644 --- a/disjob-id/src/test/java/cn/ponfee/disjob/id/snowflake/DbDistributedSnowflakeTest.java +++ b/disjob-id/src/test/java/cn/ponfee/disjob/id/snowflake/DbDistributedSnowflakeTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.id.snowflake; diff --git a/disjob-id/src/test/java/cn/ponfee/disjob/id/snowflake/SnowflakeTest.java b/disjob-id/src/test/java/cn/ponfee/disjob/id/snowflake/SnowflakeTest.java index 5a0944da1..57cc02060 100644 --- a/disjob-id/src/test/java/cn/ponfee/disjob/id/snowflake/SnowflakeTest.java +++ b/disjob-id/src/test/java/cn/ponfee/disjob/id/snowflake/SnowflakeTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.id.snowflake; diff --git a/disjob-id/src/test/java/cn/ponfee/disjob/id/snowflake/ZkDistributedSnowflakeTest.java b/disjob-id/src/test/java/cn/ponfee/disjob/id/snowflake/ZkDistributedSnowflakeTest.java index b6446124a..bd8e0149b 100644 --- a/disjob-id/src/test/java/cn/ponfee/disjob/id/snowflake/ZkDistributedSnowflakeTest.java +++ b/disjob-id/src/test/java/cn/ponfee/disjob/id/snowflake/ZkDistributedSnowflakeTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.id.snowflake; diff --git a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/AbstractRegistryProperties.java b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/AbstractRegistryProperties.java index 7711f1e58..b62b249b9 100644 --- a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/AbstractRegistryProperties.java +++ b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/AbstractRegistryProperties.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry; diff --git a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/ConnectionStateListener.java b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/ConnectionStateListener.java index febdb71b9..c94112e7e 100644 --- a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/ConnectionStateListener.java +++ b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/ConnectionStateListener.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry; diff --git a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/Discovery.java b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/Discovery.java index e845cb453..449590ae7 100644 --- a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/Discovery.java +++ b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/Discovery.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry; diff --git a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/EventType.java b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/EventType.java index 576915fc4..84d61d992 100644 --- a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/EventType.java +++ b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/EventType.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry; diff --git a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/Registry.java b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/Registry.java index a6fbfad03..c6bb1afbc 100644 --- a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/Registry.java +++ b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/Registry.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry; diff --git a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/RegistryException.java b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/RegistryException.java index ccbc6d9f5..da872cfd8 100644 --- a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/RegistryException.java +++ b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/RegistryException.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry; diff --git a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/ServerRegistry.java b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/ServerRegistry.java index 8365d6be4..55f1e3a82 100644 --- a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/ServerRegistry.java +++ b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/ServerRegistry.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry; diff --git a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/ServerRole.java b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/ServerRole.java index c7289716b..6e446787f 100644 --- a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/ServerRole.java +++ b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/ServerRole.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry; diff --git a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/SupervisorRegistry.java b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/SupervisorRegistry.java index 5184ce22f..a85a4c0b0 100644 --- a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/SupervisorRegistry.java +++ b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/SupervisorRegistry.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry; diff --git a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/WorkerRegistry.java b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/WorkerRegistry.java index f427dea0a..858d8ff05 100644 --- a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/WorkerRegistry.java +++ b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/WorkerRegistry.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry; diff --git a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/configuration/BaseServerRegistryAutoConfiguration.java b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/configuration/BaseServerRegistryAutoConfiguration.java index 6b428543f..d628c5d35 100644 --- a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/configuration/BaseServerRegistryAutoConfiguration.java +++ b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/configuration/BaseServerRegistryAutoConfiguration.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.configuration; diff --git a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/discovery/DiscoveryServer.java b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/discovery/DiscoveryServer.java index bbce45cf7..e83200629 100644 --- a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/discovery/DiscoveryServer.java +++ b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/discovery/DiscoveryServer.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.discovery; diff --git a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/discovery/DiscoverySupervisor.java b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/discovery/DiscoverySupervisor.java index 8de478ad2..e41ac8ee1 100644 --- a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/discovery/DiscoverySupervisor.java +++ b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/discovery/DiscoverySupervisor.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.discovery; diff --git a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/discovery/DiscoveryWorker.java b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/discovery/DiscoveryWorker.java index eb4193ca1..ac17c8ab0 100644 --- a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/discovery/DiscoveryWorker.java +++ b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/discovery/DiscoveryWorker.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.discovery; diff --git a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/rpc/DestinationServerRestProxy.java b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/rpc/DestinationServerRestProxy.java index 8a7e9cec3..6a2fc97cf 100644 --- a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/rpc/DestinationServerRestProxy.java +++ b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/rpc/DestinationServerRestProxy.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.rpc; diff --git a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/rpc/DestinationServerRestTemplate.java b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/rpc/DestinationServerRestTemplate.java index 806824caa..b6b264e19 100644 --- a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/rpc/DestinationServerRestTemplate.java +++ b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/rpc/DestinationServerRestTemplate.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.rpc; diff --git a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/rpc/DiscoveryServerRestProxy.java b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/rpc/DiscoveryServerRestProxy.java index 6b35b5730..d615575e4 100644 --- a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/rpc/DiscoveryServerRestProxy.java +++ b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/rpc/DiscoveryServerRestProxy.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.rpc; diff --git a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/rpc/DiscoveryServerRestTemplate.java b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/rpc/DiscoveryServerRestTemplate.java index 0d981fbcd..95679e5f6 100644 --- a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/rpc/DiscoveryServerRestTemplate.java +++ b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/rpc/DiscoveryServerRestTemplate.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.rpc; diff --git a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/rpc/RpcInvokeException.java b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/rpc/RpcInvokeException.java index 197a67c09..1be6c7c1a 100644 --- a/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/rpc/RpcInvokeException.java +++ b/disjob-registry/disjob-registry-api/src/main/java/cn/ponfee/disjob/registry/rpc/RpcInvokeException.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.rpc; diff --git a/disjob-registry/disjob-registry-api/src/test/java/cn/ponfee/disjob/common/util/RetryTest.java b/disjob-registry/disjob-registry-api/src/test/java/cn/ponfee/disjob/common/util/RetryTest.java index 6643fa50f..6c2328bde 100644 --- a/disjob-registry/disjob-registry-api/src/test/java/cn/ponfee/disjob/common/util/RetryTest.java +++ b/disjob-registry/disjob-registry-api/src/test/java/cn/ponfee/disjob/common/util/RetryTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.common.util; diff --git a/disjob-registry/disjob-registry-consul/src/main/java/cn/ponfee/disjob/registry/consul/ConsulServerRegistry.java b/disjob-registry/disjob-registry-consul/src/main/java/cn/ponfee/disjob/registry/consul/ConsulServerRegistry.java index 8c402c1f5..2e4044d7e 100644 --- a/disjob-registry/disjob-registry-consul/src/main/java/cn/ponfee/disjob/registry/consul/ConsulServerRegistry.java +++ b/disjob-registry/disjob-registry-consul/src/main/java/cn/ponfee/disjob/registry/consul/ConsulServerRegistry.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.consul; diff --git a/disjob-registry/disjob-registry-consul/src/main/java/cn/ponfee/disjob/registry/consul/ConsulSupervisorRegistry.java b/disjob-registry/disjob-registry-consul/src/main/java/cn/ponfee/disjob/registry/consul/ConsulSupervisorRegistry.java index 5ff6873d6..ec20531ac 100644 --- a/disjob-registry/disjob-registry-consul/src/main/java/cn/ponfee/disjob/registry/consul/ConsulSupervisorRegistry.java +++ b/disjob-registry/disjob-registry-consul/src/main/java/cn/ponfee/disjob/registry/consul/ConsulSupervisorRegistry.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.consul; diff --git a/disjob-registry/disjob-registry-consul/src/main/java/cn/ponfee/disjob/registry/consul/ConsulWorkerRegistry.java b/disjob-registry/disjob-registry-consul/src/main/java/cn/ponfee/disjob/registry/consul/ConsulWorkerRegistry.java index 1b3c73b0e..58cfc1c49 100644 --- a/disjob-registry/disjob-registry-consul/src/main/java/cn/ponfee/disjob/registry/consul/ConsulWorkerRegistry.java +++ b/disjob-registry/disjob-registry-consul/src/main/java/cn/ponfee/disjob/registry/consul/ConsulWorkerRegistry.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.consul; diff --git a/disjob-registry/disjob-registry-consul/src/main/java/cn/ponfee/disjob/registry/consul/configuration/ConsulRegistryProperties.java b/disjob-registry/disjob-registry-consul/src/main/java/cn/ponfee/disjob/registry/consul/configuration/ConsulRegistryProperties.java index c7fcccdae..8b16eabb0 100644 --- a/disjob-registry/disjob-registry-consul/src/main/java/cn/ponfee/disjob/registry/consul/configuration/ConsulRegistryProperties.java +++ b/disjob-registry/disjob-registry-consul/src/main/java/cn/ponfee/disjob/registry/consul/configuration/ConsulRegistryProperties.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.consul.configuration; diff --git a/disjob-registry/disjob-registry-consul/src/main/java/cn/ponfee/disjob/registry/consul/configuration/ConsulServerRegistryAutoConfiguration.java b/disjob-registry/disjob-registry-consul/src/main/java/cn/ponfee/disjob/registry/consul/configuration/ConsulServerRegistryAutoConfiguration.java index c393dfe5c..e81496141 100644 --- a/disjob-registry/disjob-registry-consul/src/main/java/cn/ponfee/disjob/registry/consul/configuration/ConsulServerRegistryAutoConfiguration.java +++ b/disjob-registry/disjob-registry-consul/src/main/java/cn/ponfee/disjob/registry/consul/configuration/ConsulServerRegistryAutoConfiguration.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.consul.configuration; diff --git a/disjob-registry/disjob-registry-consul/src/test/java/cn/ponfee/disjob/registry/consul/EmbeddedConsulServerPszymczyk.java b/disjob-registry/disjob-registry-consul/src/test/java/cn/ponfee/disjob/registry/consul/EmbeddedConsulServerPszymczyk.java index 334876da9..163989c62 100644 --- a/disjob-registry/disjob-registry-consul/src/test/java/cn/ponfee/disjob/registry/consul/EmbeddedConsulServerPszymczyk.java +++ b/disjob-registry/disjob-registry-consul/src/test/java/cn/ponfee/disjob/registry/consul/EmbeddedConsulServerPszymczyk.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.consul; diff --git a/disjob-registry/disjob-registry-consul/src/test/java/cn/ponfee/disjob/registry/consul/EmbeddedConsulServerTestcontainers.java b/disjob-registry/disjob-registry-consul/src/test/java/cn/ponfee/disjob/registry/consul/EmbeddedConsulServerTestcontainers.java index 5df6f5ba9..2c11160f5 100644 --- a/disjob-registry/disjob-registry-consul/src/test/java/cn/ponfee/disjob/registry/consul/EmbeddedConsulServerTestcontainers.java +++ b/disjob-registry/disjob-registry-consul/src/test/java/cn/ponfee/disjob/registry/consul/EmbeddedConsulServerTestcontainers.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.consul; diff --git a/disjob-registry/disjob-registry-database/src/main/java/cn/ponfee/disjob/registry/database/DatabaseServerRegistry.java b/disjob-registry/disjob-registry-database/src/main/java/cn/ponfee/disjob/registry/database/DatabaseServerRegistry.java index 9f58ac052..b931bb11c 100644 --- a/disjob-registry/disjob-registry-database/src/main/java/cn/ponfee/disjob/registry/database/DatabaseServerRegistry.java +++ b/disjob-registry/disjob-registry-database/src/main/java/cn/ponfee/disjob/registry/database/DatabaseServerRegistry.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.database; diff --git a/disjob-registry/disjob-registry-database/src/main/java/cn/ponfee/disjob/registry/database/DatabaseSupervisorRegistry.java b/disjob-registry/disjob-registry-database/src/main/java/cn/ponfee/disjob/registry/database/DatabaseSupervisorRegistry.java index e1004ac23..155a9d06e 100644 --- a/disjob-registry/disjob-registry-database/src/main/java/cn/ponfee/disjob/registry/database/DatabaseSupervisorRegistry.java +++ b/disjob-registry/disjob-registry-database/src/main/java/cn/ponfee/disjob/registry/database/DatabaseSupervisorRegistry.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.database; diff --git a/disjob-registry/disjob-registry-database/src/main/java/cn/ponfee/disjob/registry/database/DatabaseWorkerRegistry.java b/disjob-registry/disjob-registry-database/src/main/java/cn/ponfee/disjob/registry/database/DatabaseWorkerRegistry.java index 994ff3a41..c4bb9792b 100644 --- a/disjob-registry/disjob-registry-database/src/main/java/cn/ponfee/disjob/registry/database/DatabaseWorkerRegistry.java +++ b/disjob-registry/disjob-registry-database/src/main/java/cn/ponfee/disjob/registry/database/DatabaseWorkerRegistry.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.database; diff --git a/disjob-registry/disjob-registry-database/src/main/java/cn/ponfee/disjob/registry/database/configuration/DatabaseRegistryProperties.java b/disjob-registry/disjob-registry-database/src/main/java/cn/ponfee/disjob/registry/database/configuration/DatabaseRegistryProperties.java index 23d65f00f..0da9f176c 100644 --- a/disjob-registry/disjob-registry-database/src/main/java/cn/ponfee/disjob/registry/database/configuration/DatabaseRegistryProperties.java +++ b/disjob-registry/disjob-registry-database/src/main/java/cn/ponfee/disjob/registry/database/configuration/DatabaseRegistryProperties.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.database.configuration; diff --git a/disjob-registry/disjob-registry-database/src/main/java/cn/ponfee/disjob/registry/database/configuration/DatabaseServerRegistryAutoConfiguration.java b/disjob-registry/disjob-registry-database/src/main/java/cn/ponfee/disjob/registry/database/configuration/DatabaseServerRegistryAutoConfiguration.java index 74d661dfd..1244bf6d7 100644 --- a/disjob-registry/disjob-registry-database/src/main/java/cn/ponfee/disjob/registry/database/configuration/DatabaseServerRegistryAutoConfiguration.java +++ b/disjob-registry/disjob-registry-database/src/main/java/cn/ponfee/disjob/registry/database/configuration/DatabaseServerRegistryAutoConfiguration.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.database.configuration; diff --git a/disjob-registry/disjob-registry-etcd/src/main/java/cn/ponfee/disjob/registry/etcd/EtcdClient.java b/disjob-registry/disjob-registry-etcd/src/main/java/cn/ponfee/disjob/registry/etcd/EtcdClient.java index a39a5cfa1..8b24d0d2e 100644 --- a/disjob-registry/disjob-registry-etcd/src/main/java/cn/ponfee/disjob/registry/etcd/EtcdClient.java +++ b/disjob-registry/disjob-registry-etcd/src/main/java/cn/ponfee/disjob/registry/etcd/EtcdClient.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.etcd; diff --git a/disjob-registry/disjob-registry-etcd/src/main/java/cn/ponfee/disjob/registry/etcd/EtcdServerRegistry.java b/disjob-registry/disjob-registry-etcd/src/main/java/cn/ponfee/disjob/registry/etcd/EtcdServerRegistry.java index 82d89f9ab..4b7c0a9fb 100644 --- a/disjob-registry/disjob-registry-etcd/src/main/java/cn/ponfee/disjob/registry/etcd/EtcdServerRegistry.java +++ b/disjob-registry/disjob-registry-etcd/src/main/java/cn/ponfee/disjob/registry/etcd/EtcdServerRegistry.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.etcd; diff --git a/disjob-registry/disjob-registry-etcd/src/main/java/cn/ponfee/disjob/registry/etcd/EtcdSupervisorRegistry.java b/disjob-registry/disjob-registry-etcd/src/main/java/cn/ponfee/disjob/registry/etcd/EtcdSupervisorRegistry.java index 27a0fccb8..a22b69e23 100644 --- a/disjob-registry/disjob-registry-etcd/src/main/java/cn/ponfee/disjob/registry/etcd/EtcdSupervisorRegistry.java +++ b/disjob-registry/disjob-registry-etcd/src/main/java/cn/ponfee/disjob/registry/etcd/EtcdSupervisorRegistry.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.etcd; diff --git a/disjob-registry/disjob-registry-etcd/src/main/java/cn/ponfee/disjob/registry/etcd/EtcdWorkerRegistry.java b/disjob-registry/disjob-registry-etcd/src/main/java/cn/ponfee/disjob/registry/etcd/EtcdWorkerRegistry.java index 581fe1ec7..1b1b2c34e 100644 --- a/disjob-registry/disjob-registry-etcd/src/main/java/cn/ponfee/disjob/registry/etcd/EtcdWorkerRegistry.java +++ b/disjob-registry/disjob-registry-etcd/src/main/java/cn/ponfee/disjob/registry/etcd/EtcdWorkerRegistry.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.etcd; diff --git a/disjob-registry/disjob-registry-etcd/src/main/java/cn/ponfee/disjob/registry/etcd/configuration/EtcdRegistryProperties.java b/disjob-registry/disjob-registry-etcd/src/main/java/cn/ponfee/disjob/registry/etcd/configuration/EtcdRegistryProperties.java index 569cdccc4..25d770acf 100644 --- a/disjob-registry/disjob-registry-etcd/src/main/java/cn/ponfee/disjob/registry/etcd/configuration/EtcdRegistryProperties.java +++ b/disjob-registry/disjob-registry-etcd/src/main/java/cn/ponfee/disjob/registry/etcd/configuration/EtcdRegistryProperties.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.etcd.configuration; diff --git a/disjob-registry/disjob-registry-etcd/src/main/java/cn/ponfee/disjob/registry/etcd/configuration/EtcdServerRegistryAutoConfiguration.java b/disjob-registry/disjob-registry-etcd/src/main/java/cn/ponfee/disjob/registry/etcd/configuration/EtcdServerRegistryAutoConfiguration.java index 2d10cf1ba..3c01dd90f 100644 --- a/disjob-registry/disjob-registry-etcd/src/main/java/cn/ponfee/disjob/registry/etcd/configuration/EtcdServerRegistryAutoConfiguration.java +++ b/disjob-registry/disjob-registry-etcd/src/main/java/cn/ponfee/disjob/registry/etcd/configuration/EtcdServerRegistryAutoConfiguration.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.etcd.configuration; diff --git a/disjob-registry/disjob-registry-etcd/src/test/java/cn/ponfee/disjob/registry/etcd/EmbeddedEtcdServerTestcontainers.java b/disjob-registry/disjob-registry-etcd/src/test/java/cn/ponfee/disjob/registry/etcd/EmbeddedEtcdServerTestcontainers.java index 5848cdf50..432a08f0a 100644 --- a/disjob-registry/disjob-registry-etcd/src/test/java/cn/ponfee/disjob/registry/etcd/EmbeddedEtcdServerTestcontainers.java +++ b/disjob-registry/disjob-registry-etcd/src/test/java/cn/ponfee/disjob/registry/etcd/EmbeddedEtcdServerTestcontainers.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.etcd; diff --git a/disjob-registry/disjob-registry-nacos/src/main/java/cn/ponfee/disjob/registry/nacos/NacosServerRegistry.java b/disjob-registry/disjob-registry-nacos/src/main/java/cn/ponfee/disjob/registry/nacos/NacosServerRegistry.java index d977d6f7e..837ffbcf0 100644 --- a/disjob-registry/disjob-registry-nacos/src/main/java/cn/ponfee/disjob/registry/nacos/NacosServerRegistry.java +++ b/disjob-registry/disjob-registry-nacos/src/main/java/cn/ponfee/disjob/registry/nacos/NacosServerRegistry.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.nacos; diff --git a/disjob-registry/disjob-registry-nacos/src/main/java/cn/ponfee/disjob/registry/nacos/NacosSupervisorRegistry.java b/disjob-registry/disjob-registry-nacos/src/main/java/cn/ponfee/disjob/registry/nacos/NacosSupervisorRegistry.java index 3a7f1d533..729d3bb0c 100644 --- a/disjob-registry/disjob-registry-nacos/src/main/java/cn/ponfee/disjob/registry/nacos/NacosSupervisorRegistry.java +++ b/disjob-registry/disjob-registry-nacos/src/main/java/cn/ponfee/disjob/registry/nacos/NacosSupervisorRegistry.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.nacos; diff --git a/disjob-registry/disjob-registry-nacos/src/main/java/cn/ponfee/disjob/registry/nacos/NacosWorkerRegistry.java b/disjob-registry/disjob-registry-nacos/src/main/java/cn/ponfee/disjob/registry/nacos/NacosWorkerRegistry.java index 07705c753..56371fb0a 100644 --- a/disjob-registry/disjob-registry-nacos/src/main/java/cn/ponfee/disjob/registry/nacos/NacosWorkerRegistry.java +++ b/disjob-registry/disjob-registry-nacos/src/main/java/cn/ponfee/disjob/registry/nacos/NacosWorkerRegistry.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.nacos; diff --git a/disjob-registry/disjob-registry-nacos/src/main/java/cn/ponfee/disjob/registry/nacos/configuration/NacosRegistryProperties.java b/disjob-registry/disjob-registry-nacos/src/main/java/cn/ponfee/disjob/registry/nacos/configuration/NacosRegistryProperties.java index bd7a57005..7f527246d 100644 --- a/disjob-registry/disjob-registry-nacos/src/main/java/cn/ponfee/disjob/registry/nacos/configuration/NacosRegistryProperties.java +++ b/disjob-registry/disjob-registry-nacos/src/main/java/cn/ponfee/disjob/registry/nacos/configuration/NacosRegistryProperties.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.nacos.configuration; diff --git a/disjob-registry/disjob-registry-nacos/src/main/java/cn/ponfee/disjob/registry/nacos/configuration/NacosServerRegistryAutoConfiguration.java b/disjob-registry/disjob-registry-nacos/src/main/java/cn/ponfee/disjob/registry/nacos/configuration/NacosServerRegistryAutoConfiguration.java index c72a00ce2..c95641965 100644 --- a/disjob-registry/disjob-registry-nacos/src/main/java/cn/ponfee/disjob/registry/nacos/configuration/NacosServerRegistryAutoConfiguration.java +++ b/disjob-registry/disjob-registry-nacos/src/main/java/cn/ponfee/disjob/registry/nacos/configuration/NacosServerRegistryAutoConfiguration.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.nacos.configuration; diff --git a/disjob-registry/disjob-registry-nacos/src/test/java/cn/ponfee/disjob/registry/nacos/EmbeddedNacosServerTestcontainers.java b/disjob-registry/disjob-registry-nacos/src/test/java/cn/ponfee/disjob/registry/nacos/EmbeddedNacosServerTestcontainers.java index 12a329c15..a1522369a 100644 --- a/disjob-registry/disjob-registry-nacos/src/test/java/cn/ponfee/disjob/registry/nacos/EmbeddedNacosServerTestcontainers.java +++ b/disjob-registry/disjob-registry-nacos/src/test/java/cn/ponfee/disjob/registry/nacos/EmbeddedNacosServerTestcontainers.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.nacos; diff --git a/disjob-registry/disjob-registry-redis/src/main/java/cn/ponfee/disjob/registry/redis/RedisServerRegistry.java b/disjob-registry/disjob-registry-redis/src/main/java/cn/ponfee/disjob/registry/redis/RedisServerRegistry.java index 30b14771b..231d13bea 100644 --- a/disjob-registry/disjob-registry-redis/src/main/java/cn/ponfee/disjob/registry/redis/RedisServerRegistry.java +++ b/disjob-registry/disjob-registry-redis/src/main/java/cn/ponfee/disjob/registry/redis/RedisServerRegistry.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.redis; diff --git a/disjob-registry/disjob-registry-redis/src/main/java/cn/ponfee/disjob/registry/redis/RedisSupervisorRegistry.java b/disjob-registry/disjob-registry-redis/src/main/java/cn/ponfee/disjob/registry/redis/RedisSupervisorRegistry.java index 320eda705..9bfebc982 100644 --- a/disjob-registry/disjob-registry-redis/src/main/java/cn/ponfee/disjob/registry/redis/RedisSupervisorRegistry.java +++ b/disjob-registry/disjob-registry-redis/src/main/java/cn/ponfee/disjob/registry/redis/RedisSupervisorRegistry.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.redis; diff --git a/disjob-registry/disjob-registry-redis/src/main/java/cn/ponfee/disjob/registry/redis/RedisWorkerRegistry.java b/disjob-registry/disjob-registry-redis/src/main/java/cn/ponfee/disjob/registry/redis/RedisWorkerRegistry.java index 03c5d9fbd..3a6a9ecf0 100644 --- a/disjob-registry/disjob-registry-redis/src/main/java/cn/ponfee/disjob/registry/redis/RedisWorkerRegistry.java +++ b/disjob-registry/disjob-registry-redis/src/main/java/cn/ponfee/disjob/registry/redis/RedisWorkerRegistry.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.redis; diff --git a/disjob-registry/disjob-registry-redis/src/main/java/cn/ponfee/disjob/registry/redis/configuration/RedisRegistryProperties.java b/disjob-registry/disjob-registry-redis/src/main/java/cn/ponfee/disjob/registry/redis/configuration/RedisRegistryProperties.java index 5f0bb231d..4bf39797e 100644 --- a/disjob-registry/disjob-registry-redis/src/main/java/cn/ponfee/disjob/registry/redis/configuration/RedisRegistryProperties.java +++ b/disjob-registry/disjob-registry-redis/src/main/java/cn/ponfee/disjob/registry/redis/configuration/RedisRegistryProperties.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.redis.configuration; diff --git a/disjob-registry/disjob-registry-redis/src/main/java/cn/ponfee/disjob/registry/redis/configuration/RedisServerRegistryAutoConfiguration.java b/disjob-registry/disjob-registry-redis/src/main/java/cn/ponfee/disjob/registry/redis/configuration/RedisServerRegistryAutoConfiguration.java index 60a104821..deefbb707 100644 --- a/disjob-registry/disjob-registry-redis/src/main/java/cn/ponfee/disjob/registry/redis/configuration/RedisServerRegistryAutoConfiguration.java +++ b/disjob-registry/disjob-registry-redis/src/main/java/cn/ponfee/disjob/registry/redis/configuration/RedisServerRegistryAutoConfiguration.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.redis.configuration; diff --git a/disjob-registry/disjob-registry-zookeeper/src/main/java/cn/ponfee/disjob/registry/zookeeper/CuratorFrameworkClient.java b/disjob-registry/disjob-registry-zookeeper/src/main/java/cn/ponfee/disjob/registry/zookeeper/CuratorFrameworkClient.java index 1ecd8a472..ad1ac2f6e 100644 --- a/disjob-registry/disjob-registry-zookeeper/src/main/java/cn/ponfee/disjob/registry/zookeeper/CuratorFrameworkClient.java +++ b/disjob-registry/disjob-registry-zookeeper/src/main/java/cn/ponfee/disjob/registry/zookeeper/CuratorFrameworkClient.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.zookeeper; diff --git a/disjob-registry/disjob-registry-zookeeper/src/main/java/cn/ponfee/disjob/registry/zookeeper/ZookeeperServerRegistry.java b/disjob-registry/disjob-registry-zookeeper/src/main/java/cn/ponfee/disjob/registry/zookeeper/ZookeeperServerRegistry.java index 68a8583c1..3d7d8e25b 100644 --- a/disjob-registry/disjob-registry-zookeeper/src/main/java/cn/ponfee/disjob/registry/zookeeper/ZookeeperServerRegistry.java +++ b/disjob-registry/disjob-registry-zookeeper/src/main/java/cn/ponfee/disjob/registry/zookeeper/ZookeeperServerRegistry.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.zookeeper; diff --git a/disjob-registry/disjob-registry-zookeeper/src/main/java/cn/ponfee/disjob/registry/zookeeper/ZookeeperSupervisorRegistry.java b/disjob-registry/disjob-registry-zookeeper/src/main/java/cn/ponfee/disjob/registry/zookeeper/ZookeeperSupervisorRegistry.java index 7498eca73..f68f8617c 100644 --- a/disjob-registry/disjob-registry-zookeeper/src/main/java/cn/ponfee/disjob/registry/zookeeper/ZookeeperSupervisorRegistry.java +++ b/disjob-registry/disjob-registry-zookeeper/src/main/java/cn/ponfee/disjob/registry/zookeeper/ZookeeperSupervisorRegistry.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.zookeeper; diff --git a/disjob-registry/disjob-registry-zookeeper/src/main/java/cn/ponfee/disjob/registry/zookeeper/ZookeeperWorkerRegistry.java b/disjob-registry/disjob-registry-zookeeper/src/main/java/cn/ponfee/disjob/registry/zookeeper/ZookeeperWorkerRegistry.java index 4e8724c15..d0f3cb056 100644 --- a/disjob-registry/disjob-registry-zookeeper/src/main/java/cn/ponfee/disjob/registry/zookeeper/ZookeeperWorkerRegistry.java +++ b/disjob-registry/disjob-registry-zookeeper/src/main/java/cn/ponfee/disjob/registry/zookeeper/ZookeeperWorkerRegistry.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.zookeeper; diff --git a/disjob-registry/disjob-registry-zookeeper/src/main/java/cn/ponfee/disjob/registry/zookeeper/configuration/ZookeeperRegistryProperties.java b/disjob-registry/disjob-registry-zookeeper/src/main/java/cn/ponfee/disjob/registry/zookeeper/configuration/ZookeeperRegistryProperties.java index f656af205..1d7954aa5 100644 --- a/disjob-registry/disjob-registry-zookeeper/src/main/java/cn/ponfee/disjob/registry/zookeeper/configuration/ZookeeperRegistryProperties.java +++ b/disjob-registry/disjob-registry-zookeeper/src/main/java/cn/ponfee/disjob/registry/zookeeper/configuration/ZookeeperRegistryProperties.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.zookeeper.configuration; diff --git a/disjob-registry/disjob-registry-zookeeper/src/main/java/cn/ponfee/disjob/registry/zookeeper/configuration/ZookeeperServerRegistryAutoConfiguration.java b/disjob-registry/disjob-registry-zookeeper/src/main/java/cn/ponfee/disjob/registry/zookeeper/configuration/ZookeeperServerRegistryAutoConfiguration.java index 01fdade38..62ffff402 100644 --- a/disjob-registry/disjob-registry-zookeeper/src/main/java/cn/ponfee/disjob/registry/zookeeper/configuration/ZookeeperServerRegistryAutoConfiguration.java +++ b/disjob-registry/disjob-registry-zookeeper/src/main/java/cn/ponfee/disjob/registry/zookeeper/configuration/ZookeeperServerRegistryAutoConfiguration.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.zookeeper.configuration; diff --git a/disjob-registry/disjob-registry-zookeeper/src/test/java/cn/ponfee/disjob/registry/zookeeper/EmbeddedZookeeperServer.java b/disjob-registry/disjob-registry-zookeeper/src/test/java/cn/ponfee/disjob/registry/zookeeper/EmbeddedZookeeperServer.java index 912025b10..289ad6d3c 100644 --- a/disjob-registry/disjob-registry-zookeeper/src/test/java/cn/ponfee/disjob/registry/zookeeper/EmbeddedZookeeperServer.java +++ b/disjob-registry/disjob-registry-zookeeper/src/test/java/cn/ponfee/disjob/registry/zookeeper/EmbeddedZookeeperServer.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.registry.zookeeper; diff --git a/disjob-samples/disjob-samples-frameless-worker/src/main/java/cn/ponfee/disjob/samples/worker/WorkerFramelessMain.java b/disjob-samples/disjob-samples-frameless-worker/src/main/java/cn/ponfee/disjob/samples/worker/WorkerFramelessMain.java index d9c04c205..7f4b61d7b 100644 --- a/disjob-samples/disjob-samples-frameless-worker/src/main/java/cn/ponfee/disjob/samples/worker/WorkerFramelessMain.java +++ b/disjob-samples/disjob-samples-frameless-worker/src/main/java/cn/ponfee/disjob/samples/worker/WorkerFramelessMain.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.samples.worker; diff --git a/disjob-samples/disjob-samples-frameless-worker/src/main/java/cn/ponfee/disjob/samples/worker/redis/AbstractRedisTemplateCreator.java b/disjob-samples/disjob-samples-frameless-worker/src/main/java/cn/ponfee/disjob/samples/worker/redis/AbstractRedisTemplateCreator.java index 9c411f3c2..1c7b1cee6 100644 --- a/disjob-samples/disjob-samples-frameless-worker/src/main/java/cn/ponfee/disjob/samples/worker/redis/AbstractRedisTemplateCreator.java +++ b/disjob-samples/disjob-samples-frameless-worker/src/main/java/cn/ponfee/disjob/samples/worker/redis/AbstractRedisTemplateCreator.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.samples.worker.redis; diff --git a/disjob-samples/disjob-samples-frameless-worker/src/main/java/cn/ponfee/disjob/samples/worker/redis/ClusterRedisTemplateCreator.java b/disjob-samples/disjob-samples-frameless-worker/src/main/java/cn/ponfee/disjob/samples/worker/redis/ClusterRedisTemplateCreator.java index e16255ea9..5637325f0 100644 --- a/disjob-samples/disjob-samples-frameless-worker/src/main/java/cn/ponfee/disjob/samples/worker/redis/ClusterRedisTemplateCreator.java +++ b/disjob-samples/disjob-samples-frameless-worker/src/main/java/cn/ponfee/disjob/samples/worker/redis/ClusterRedisTemplateCreator.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.samples.worker.redis; diff --git a/disjob-samples/disjob-samples-frameless-worker/src/main/java/cn/ponfee/disjob/samples/worker/redis/SentinelRedisTemplateCreator.java b/disjob-samples/disjob-samples-frameless-worker/src/main/java/cn/ponfee/disjob/samples/worker/redis/SentinelRedisTemplateCreator.java index 6f8364708..75f4fc5f6 100644 --- a/disjob-samples/disjob-samples-frameless-worker/src/main/java/cn/ponfee/disjob/samples/worker/redis/SentinelRedisTemplateCreator.java +++ b/disjob-samples/disjob-samples-frameless-worker/src/main/java/cn/ponfee/disjob/samples/worker/redis/SentinelRedisTemplateCreator.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.samples.worker.redis; diff --git a/disjob-samples/disjob-samples-frameless-worker/src/main/java/cn/ponfee/disjob/samples/worker/redis/StandaloneRedisTemplateCreator.java b/disjob-samples/disjob-samples-frameless-worker/src/main/java/cn/ponfee/disjob/samples/worker/redis/StandaloneRedisTemplateCreator.java index 1fbfa4d53..01bea3715 100644 --- a/disjob-samples/disjob-samples-frameless-worker/src/main/java/cn/ponfee/disjob/samples/worker/redis/StandaloneRedisTemplateCreator.java +++ b/disjob-samples/disjob-samples-frameless-worker/src/main/java/cn/ponfee/disjob/samples/worker/redis/StandaloneRedisTemplateCreator.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.samples.worker.redis; diff --git a/disjob-samples/disjob-samples-frameless-worker/src/main/java/cn/ponfee/disjob/samples/worker/util/JobHandlerParser.java b/disjob-samples/disjob-samples-frameless-worker/src/main/java/cn/ponfee/disjob/samples/worker/util/JobHandlerParser.java index bf687e722..f0069c286 100644 --- a/disjob-samples/disjob-samples-frameless-worker/src/main/java/cn/ponfee/disjob/samples/worker/util/JobHandlerParser.java +++ b/disjob-samples/disjob-samples-frameless-worker/src/main/java/cn/ponfee/disjob/samples/worker/util/JobHandlerParser.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.samples.worker.util; diff --git a/disjob-samples/disjob-samples-frameless-worker/src/main/java/cn/ponfee/disjob/samples/worker/vertx/VertxWebServer.java b/disjob-samples/disjob-samples-frameless-worker/src/main/java/cn/ponfee/disjob/samples/worker/vertx/VertxWebServer.java index 19c68407f..da811164c 100644 --- a/disjob-samples/disjob-samples-frameless-worker/src/main/java/cn/ponfee/disjob/samples/worker/vertx/VertxWebServer.java +++ b/disjob-samples/disjob-samples-frameless-worker/src/main/java/cn/ponfee/disjob/samples/worker/vertx/VertxWebServer.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.samples.worker.vertx; diff --git a/disjob-samples/disjob-samples-springboot-common/src/main/java/cn/ponfee/disjob/samples/common/AbstractSamplesApplication.java b/disjob-samples/disjob-samples-springboot-common/src/main/java/cn/ponfee/disjob/samples/common/AbstractSamplesApplication.java index 87aa2bee7..7c89de51c 100644 --- a/disjob-samples/disjob-samples-springboot-common/src/main/java/cn/ponfee/disjob/samples/common/AbstractSamplesApplication.java +++ b/disjob-samples/disjob-samples-springboot-common/src/main/java/cn/ponfee/disjob/samples/common/AbstractSamplesApplication.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.samples.common; diff --git a/disjob-samples/disjob-samples-springboot-common/src/main/java/cn/ponfee/disjob/samples/common/configuration/SpringWebConfiguration.java b/disjob-samples/disjob-samples-springboot-common/src/main/java/cn/ponfee/disjob/samples/common/configuration/SpringWebConfiguration.java index 76af7fa77..d1170ccda 100644 --- a/disjob-samples/disjob-samples-springboot-common/src/main/java/cn/ponfee/disjob/samples/common/configuration/SpringWebConfiguration.java +++ b/disjob-samples/disjob-samples-springboot-common/src/main/java/cn/ponfee/disjob/samples/common/configuration/SpringWebConfiguration.java @@ -1,10 +1,19 @@ -///* __________ _____ *\ -//** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -//** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -//** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -//** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -//** \/ \/ \/ ** -//\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ + // //package cn.ponfee.disjob.samples.common.configuration; // diff --git a/disjob-samples/disjob-samples-springboot-common/src/main/java/cn/ponfee/disjob/samples/common/configuration/SpringWebExceptionHandler.java b/disjob-samples/disjob-samples-springboot-common/src/main/java/cn/ponfee/disjob/samples/common/configuration/SpringWebExceptionHandler.java index 7ac8caf0f..7b69d072c 100644 --- a/disjob-samples/disjob-samples-springboot-common/src/main/java/cn/ponfee/disjob/samples/common/configuration/SpringWebExceptionHandler.java +++ b/disjob-samples/disjob-samples-springboot-common/src/main/java/cn/ponfee/disjob/samples/common/configuration/SpringWebExceptionHandler.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.samples.common.configuration; diff --git a/disjob-samples/disjob-samples-springboot-merged/src/main/java/cn/ponfee/disjob/samples/merged/MergedApplication.java b/disjob-samples/disjob-samples-springboot-merged/src/main/java/cn/ponfee/disjob/samples/merged/MergedApplication.java index a3d5d3569..43fef6aca 100644 --- a/disjob-samples/disjob-samples-springboot-merged/src/main/java/cn/ponfee/disjob/samples/merged/MergedApplication.java +++ b/disjob-samples/disjob-samples-springboot-merged/src/main/java/cn/ponfee/disjob/samples/merged/MergedApplication.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.samples.merged; diff --git a/disjob-samples/disjob-samples-springboot-supervisor/src/main/java/cn/ponfee/disjob/samples/supervisor/SupervisorApplication.java b/disjob-samples/disjob-samples-springboot-supervisor/src/main/java/cn/ponfee/disjob/samples/supervisor/SupervisorApplication.java index e63610e0c..b3efead3a 100644 --- a/disjob-samples/disjob-samples-springboot-supervisor/src/main/java/cn/ponfee/disjob/samples/supervisor/SupervisorApplication.java +++ b/disjob-samples/disjob-samples-springboot-supervisor/src/main/java/cn/ponfee/disjob/samples/supervisor/SupervisorApplication.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.samples.supervisor; diff --git a/disjob-samples/disjob-samples-springboot-worker/src/main/java/cn/ponfee/disjob/samples/worker/WorkerApplication.java b/disjob-samples/disjob-samples-springboot-worker/src/main/java/cn/ponfee/disjob/samples/worker/WorkerApplication.java index 47fd85cc9..362e9e20a 100644 --- a/disjob-samples/disjob-samples-springboot-worker/src/main/java/cn/ponfee/disjob/samples/worker/WorkerApplication.java +++ b/disjob-samples/disjob-samples-springboot-worker/src/main/java/cn/ponfee/disjob/samples/worker/WorkerApplication.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.samples.worker; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/SupervisorStartup.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/SupervisorStartup.java index fba9d51e8..929be083c 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/SupervisorStartup.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/SupervisorStartup.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/AuthorizeGroupService.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/AuthorizeGroupService.java index ef906cb44..f4619577b 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/AuthorizeGroupService.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/AuthorizeGroupService.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.application; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/EventSubscribeService.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/EventSubscribeService.java index 2eb21baba..b41bb22b5 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/EventSubscribeService.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/EventSubscribeService.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.application; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/OpenapiService.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/OpenapiService.java index f8156ceda..40c7751bb 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/OpenapiService.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/OpenapiService.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_ ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ \___ http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.application; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/SchedGroupService.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/SchedGroupService.java index d9622af2d..3ad37e9d6 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/SchedGroupService.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/SchedGroupService.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.application; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/ServerInvokeService.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/ServerInvokeService.java index 4cac82914..c1fa3e729 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/ServerInvokeService.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/ServerInvokeService.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.application; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/converter/CommonMapper.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/converter/CommonMapper.java index 1d297a50f..49877084b 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/converter/CommonMapper.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/converter/CommonMapper.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.application.converter; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/converter/SchedGroupConverter.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/converter/SchedGroupConverter.java index 807b2cb2c..1eb911f6c 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/converter/SchedGroupConverter.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/converter/SchedGroupConverter.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.application.converter; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/converter/SchedJobConverter.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/converter/SchedJobConverter.java index da88b234b..39d8a1cc0 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/converter/SchedJobConverter.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/converter/SchedJobConverter.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.application.converter; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/converter/ServerMetricsConverter.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/converter/ServerMetricsConverter.java index a23c2df3c..235d32b68 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/converter/ServerMetricsConverter.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/converter/ServerMetricsConverter.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.application.converter; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/AbstractSchedJobRequest.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/AbstractSchedJobRequest.java index 8323c3e82..9ccfceb13 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/AbstractSchedJobRequest.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/AbstractSchedJobRequest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.application.request; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/ConfigureAllWorkerRequest.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/ConfigureAllWorkerRequest.java index f1b0c3682..40acc83ae 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/ConfigureAllWorkerRequest.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/ConfigureAllWorkerRequest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.application.request; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/ConfigureOneWorkerRequest.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/ConfigureOneWorkerRequest.java index 756dae236..b140d7f1e 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/ConfigureOneWorkerRequest.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/ConfigureOneWorkerRequest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.application.request; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedGroupAddRequest.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedGroupAddRequest.java index 880addb5f..0f545f9e1 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedGroupAddRequest.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedGroupAddRequest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.application.request; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedGroupPageRequest.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedGroupPageRequest.java index a26685c0a..4d61f3905 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedGroupPageRequest.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedGroupPageRequest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.application.request; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedGroupUpdateRequest.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedGroupUpdateRequest.java index 245e87674..b80a28608 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedGroupUpdateRequest.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedGroupUpdateRequest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.application.request; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedInstancePageRequest.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedInstancePageRequest.java index 4a69f230f..824e6f32b 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedInstancePageRequest.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedInstancePageRequest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.application.request; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedJobAddRequest.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedJobAddRequest.java index abe02f6b3..0ab63a779 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedJobAddRequest.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedJobAddRequest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.application.request; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedJobPageRequest.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedJobPageRequest.java index cbfe3f542..23542c12d 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedJobPageRequest.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedJobPageRequest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.application.request; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedJobSearchRequest.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedJobSearchRequest.java index 0032dc36e..19df7e0f6 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedJobSearchRequest.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedJobSearchRequest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.application.request; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedJobUpdateRequest.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedJobUpdateRequest.java index 476c4c648..6d369def1 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedJobUpdateRequest.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/request/SchedJobUpdateRequest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.application.request; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/response/SchedGroupResponse.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/response/SchedGroupResponse.java index 7c70e7de0..5a9a83c15 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/response/SchedGroupResponse.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/response/SchedGroupResponse.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.application.response; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/response/SchedInstanceResponse.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/response/SchedInstanceResponse.java index 1f457ea7a..a89bb213d 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/response/SchedInstanceResponse.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/response/SchedInstanceResponse.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.application.response; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/response/SchedJobResponse.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/response/SchedJobResponse.java index e36ea9f19..62e457287 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/response/SchedJobResponse.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/response/SchedJobResponse.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.application.response; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/response/SchedTaskResponse.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/response/SchedTaskResponse.java index 423f5c4e7..124be2199 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/response/SchedTaskResponse.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/response/SchedTaskResponse.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.application.response; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/response/ServerMetricsResponse.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/response/ServerMetricsResponse.java index a765752ce..97d31ed32 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/response/ServerMetricsResponse.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/response/ServerMetricsResponse.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.application.response; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/response/SupervisorMetricsResponse.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/response/SupervisorMetricsResponse.java index 40801dbab..7100114e6 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/response/SupervisorMetricsResponse.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/response/SupervisorMetricsResponse.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.application.response; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/response/WorkerMetricsResponse.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/response/WorkerMetricsResponse.java index 5d6050d74..6f971caba 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/response/WorkerMetricsResponse.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/response/WorkerMetricsResponse.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.application.response; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/value/DisjobGroup.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/value/DisjobGroup.java index ad874fe5e..7e202cdf1 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/value/DisjobGroup.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/application/value/DisjobGroup.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.application.value; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/auth/AuthenticationConfigurer.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/auth/AuthenticationConfigurer.java index ef182db89..c565d048f 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/auth/AuthenticationConfigurer.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/auth/AuthenticationConfigurer.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.auth; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/auth/SupervisorAuthentication.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/auth/SupervisorAuthentication.java index b53b288b7..8afe606b9 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/auth/SupervisorAuthentication.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/auth/SupervisorAuthentication.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.auth; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/base/AbstractDataSourceConfig.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/base/AbstractDataSourceConfig.java index 625246593..7ed325771 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/base/AbstractDataSourceConfig.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/base/AbstractDataSourceConfig.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.base; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/base/AbstractDataSourceConfig.java.bak b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/base/AbstractDataSourceConfig.java.bak index 300743b36..a45d8e989 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/base/AbstractDataSourceConfig.java.bak +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/base/AbstractDataSourceConfig.java.bak @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.base; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/base/SupervisorConstants.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/base/SupervisorConstants.java index 03a196138..c54485cb8 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/base/SupervisorConstants.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/base/SupervisorConstants.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.base; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/component/AbstractJobManager.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/component/AbstractJobManager.java index 1d0646df2..c574c112c 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/component/AbstractJobManager.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/component/AbstractJobManager.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.component; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/component/DistributedJobManager.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/component/DistributedJobManager.java index 593723a87..0555ea26c 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/component/DistributedJobManager.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/component/DistributedJobManager.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.component; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/component/DistributedJobQuerier.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/component/DistributedJobQuerier.java index 70c41517d..c0d22ff24 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/component/DistributedJobQuerier.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/component/DistributedJobQuerier.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.component; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/configuration/EnableSupervisor.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/configuration/EnableSupervisor.java index 8e42c9d27..f3f57b26a 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/configuration/EnableSupervisor.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/configuration/EnableSupervisor.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.configuration; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/configuration/SupervisorLifecycle.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/configuration/SupervisorLifecycle.java index b52c8a948..d4cf77424 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/configuration/SupervisorLifecycle.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/configuration/SupervisorLifecycle.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.configuration; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/configuration/SupervisorProperties.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/configuration/SupervisorProperties.java index bd8141efe..e4dea2a4f 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/configuration/SupervisorProperties.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/configuration/SupervisorProperties.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.configuration; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dag/WorkflowGraph.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dag/WorkflowGraph.java index f95112325..418fc1b78 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dag/WorkflowGraph.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dag/WorkflowGraph.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.dag; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dao/SupervisorDataSourceConfig.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dao/SupervisorDataSourceConfig.java index 7ed7db452..e01ab7fc8 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dao/SupervisorDataSourceConfig.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dao/SupervisorDataSourceConfig.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.dao; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dao/mapper/SchedDependMapper.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dao/mapper/SchedDependMapper.java index 2e2116149..410db6425 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dao/mapper/SchedDependMapper.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dao/mapper/SchedDependMapper.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.dao.mapper; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dao/mapper/SchedGroupMapper.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dao/mapper/SchedGroupMapper.java index 27618c879..ea115009f 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dao/mapper/SchedGroupMapper.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dao/mapper/SchedGroupMapper.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.dao.mapper; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dao/mapper/SchedInstanceMapper.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dao/mapper/SchedInstanceMapper.java index 065cc113f..d4ad3bda7 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dao/mapper/SchedInstanceMapper.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dao/mapper/SchedInstanceMapper.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.dao.mapper; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dao/mapper/SchedJobMapper.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dao/mapper/SchedJobMapper.java index ef3b5f140..4f50e6d20 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dao/mapper/SchedJobMapper.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dao/mapper/SchedJobMapper.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.dao.mapper; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dao/mapper/SchedTaskMapper.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dao/mapper/SchedTaskMapper.java index d9c3ec4fd..05470685c 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dao/mapper/SchedTaskMapper.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dao/mapper/SchedTaskMapper.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.dao.mapper; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dao/mapper/SchedWorkflowMapper.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dao/mapper/SchedWorkflowMapper.java index b39f2c478..1def42d8e 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dao/mapper/SchedWorkflowMapper.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/dao/mapper/SchedWorkflowMapper.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.dao.mapper; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/instance/GeneralInstanceCreator.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/instance/GeneralInstanceCreator.java index b334c9e6b..e03d729a6 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/instance/GeneralInstanceCreator.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/instance/GeneralInstanceCreator.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.instance; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/instance/TriggerInstance.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/instance/TriggerInstance.java index e452e7846..f1d891398 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/instance/TriggerInstance.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/instance/TriggerInstance.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.instance; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/instance/TriggerInstanceCreator.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/instance/TriggerInstanceCreator.java index 0af17b6b5..73f256f2e 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/instance/TriggerInstanceCreator.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/instance/TriggerInstanceCreator.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.instance; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/instance/WorkflowInstanceCreator.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/instance/WorkflowInstanceCreator.java index 606b1fc4a..909232e3c 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/instance/WorkflowInstanceCreator.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/instance/WorkflowInstanceCreator.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.instance; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/provider/SupervisorOpenapiProvider.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/provider/SupervisorOpenapiProvider.java index d95e02fb7..e8e65d005 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/provider/SupervisorOpenapiProvider.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/provider/SupervisorOpenapiProvider.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.provider; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/provider/SupervisorRpcProvider.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/provider/SupervisorRpcProvider.java index 872a22424..16804b340 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/provider/SupervisorRpcProvider.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/provider/SupervisorRpcProvider.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.provider; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/thread/RunningInstanceScanner.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/thread/RunningInstanceScanner.java index 5c41da0c9..729832f84 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/thread/RunningInstanceScanner.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/thread/RunningInstanceScanner.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.thread; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/thread/TriggeringJobScanner.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/thread/TriggeringJobScanner.java index fe2cb2c23..a0bcbef22 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/thread/TriggeringJobScanner.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/thread/TriggeringJobScanner.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.thread; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/thread/WaitingInstanceScanner.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/thread/WaitingInstanceScanner.java index 2e7425f81..545d0a7da 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/thread/WaitingInstanceScanner.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/thread/WaitingInstanceScanner.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.thread; diff --git a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/util/TriggerTimeUtils.java b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/util/TriggerTimeUtils.java index 2d7e7c466..83b17cdbe 100644 --- a/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/util/TriggerTimeUtils.java +++ b/disjob-supervisor/src/main/java/cn/ponfee/disjob/supervisor/util/TriggerTimeUtils.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.util; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/AllTestSuite.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/AllTestSuite.java index e37af401c..9ccc2f6a3 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/AllTestSuite.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/AllTestSuite.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/SpringBootTestApplication.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/SpringBootTestApplication.java index 1cb34ab00..4231fdf57 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/SpringBootTestApplication.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/SpringBootTestApplication.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/SpringBootTestBase.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/SpringBootTestBase.java index b0beabca0..a759d48c6 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/SpringBootTestBase.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/SpringBootTestBase.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/SpringBootTestCollector.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/SpringBootTestCollector.java index 2191a1ed2..d28445533 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/SpringBootTestCollector.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/SpringBootTestCollector.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/application/ModelClassFileDiffTest.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/application/ModelClassFileDiffTest.java index b85795c2e..3336bf3d5 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/application/ModelClassFileDiffTest.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/application/ModelClassFileDiffTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.application; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/base/RateLimiterTest.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/base/RateLimiterTest.java index 35810e53a..4a8ffc771 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/base/RateLimiterTest.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/base/RateLimiterTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.base; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/base/RedisLockTest.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/base/RedisLockTest.java index 4a77ee46f..4fed2201d 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/base/RedisLockTest.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/base/RedisLockTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.base; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/base/SpringContextTest.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/base/SpringContextTest.java index 9c9a32602..cd3dc891c 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/base/SpringContextTest.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/base/SpringContextTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.base; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/base/ThreadExceptionTest.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/base/ThreadExceptionTest.java index 5342121b0..5f6e1de60 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/base/ThreadExceptionTest.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/base/ThreadExceptionTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.base; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/base/WorkerRpcServiceTest.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/base/WorkerRpcServiceTest.java index ed8584764..79bbf4035 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/base/WorkerRpcServiceTest.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/base/WorkerRpcServiceTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.base; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/config/AuthenticationCallWorker.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/config/AuthenticationCallWorker.java index c298ae6cf..1260a1220 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/config/AuthenticationCallWorker.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/config/AuthenticationCallWorker.java @@ -1,10 +1,19 @@ -///* __________ _____ *\ -//** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -//** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -//** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -//** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -//** \/ \/ \/ ** -//\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ + // //package cn.ponfee.disjob.supervisor.config; // diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/config/CommonConfiguration.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/config/CommonConfiguration.java index e4dcc55d8..cf9ce9613 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/config/CommonConfiguration.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/config/CommonConfiguration.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.config; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/config/DisjobConfiguration.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/config/DisjobConfiguration.java index b2dd869de..fbda33c13 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/config/DisjobConfiguration.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/config/DisjobConfiguration.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.config; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/config/InitializedContextCustomizerFactory.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/config/InitializedContextCustomizerFactory.java index 698208b40..f5b3fa47d 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/config/InitializedContextCustomizerFactory.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/config/InitializedContextCustomizerFactory.java @@ -1,10 +1,19 @@ -///* __________ _____ *\ -//** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -//** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -//** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -//** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -//** \/ \/ \/ ** -//\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ + // //package cn.ponfee.disjob.supervisor.config; // diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/config/WebsocketDemo.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/config/WebsocketDemo.java index 5669e1e2f..02831f1da 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/config/WebsocketDemo.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/config/WebsocketDemo.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ //package cn.ponfee.disjob.supervisor.config; // diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/model/ExecuteParamTest.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/model/ExecuteParamTest.java index 8e036f783..0b2475ecd 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/model/ExecuteParamTest.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/model/ExecuteParamTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.model; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/model/RouteTest.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/model/RouteTest.java index ddd2a6bea..c937ed55b 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/model/RouteTest.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/model/RouteTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.model; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/model/SchedJobMapperTest.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/model/SchedJobMapperTest.java index bc2f6235b..66fafbbd8 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/model/SchedJobMapperTest.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/model/SchedJobMapperTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.model; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/model/TriggerValueTest.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/model/TriggerValueTest.java index eb56d2784..d3786d7c1 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/model/TriggerValueTest.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/model/TriggerValueTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.model; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/transaction/AbstractTxManagerTestService.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/transaction/AbstractTxManagerTestService.java index 0053d8ba7..989f4dd1b 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/transaction/AbstractTxManagerTestService.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/transaction/AbstractTxManagerTestService.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.transaction; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/transaction/JobTxManagerTest.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/transaction/JobTxManagerTest.java index b0166e44c..cccb3c669 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/transaction/JobTxManagerTest.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/transaction/JobTxManagerTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.transaction; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/transaction/JobTxManagerTestService.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/transaction/JobTxManagerTestService.java index 49470872a..e404ad8cd 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/transaction/JobTxManagerTestService.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/transaction/JobTxManagerTestService.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.transaction; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/transaction/TxManagerTestBase.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/transaction/TxManagerTestBase.java index f42b85988..b86bd534b 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/transaction/TxManagerTestBase.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/transaction/TxManagerTestBase.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.transaction; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/AssertjTest.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/AssertjTest.java index 61a74b253..63984eb9c 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/AssertjTest.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/AssertjTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.util; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/CommonTest.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/CommonTest.java index 698d58046..52b90d171 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/CommonTest.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/CommonTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.util; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/CronExpressionTest.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/CronExpressionTest.java index 3e1eab304..3a7c7d3de 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/CronExpressionTest.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/CronExpressionTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.util; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/HashTest.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/HashTest.java index 46f7f15b9..45c857d4b 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/HashTest.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/HashTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.util; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/LambdaStreamTest.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/LambdaStreamTest.java index 55a68da73..c9cc9754e 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/LambdaStreamTest.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/LambdaStreamTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.util; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/NumbersTest.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/NumbersTest.java index a1cadbe25..0e7e8f5a6 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/NumbersTest.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/NumbersTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.util; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/ObjectUtilsTest.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/ObjectUtilsTest.java index eadfb3df8..84b69400d 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/ObjectUtilsTest.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/ObjectUtilsTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.util; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/ParallelStreamTest.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/ParallelStreamTest.java index af26f030e..550aea637 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/ParallelStreamTest.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/ParallelStreamTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.util; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/ScheduledExecutorTest.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/ScheduledExecutorTest.java index 3e8981ef1..c5b4c7911 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/ScheduledExecutorTest.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/ScheduledExecutorTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.util; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/ScheduledTaskTest.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/ScheduledTaskTest.java index 9e4e94b1a..1567e4e74 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/ScheduledTaskTest.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/ScheduledTaskTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.util; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/TimingWheelTest.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/TimingWheelTest.java index e9b3dd40a..01134fd24 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/TimingWheelTest.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/TimingWheelTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.util; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/TreeMapTest.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/TreeMapTest.java index 707db9b9e..14358a685 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/TreeMapTest.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/TreeMapTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.util; diff --git a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/TriggerTimeUtilsTest.java b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/TriggerTimeUtilsTest.java index ed2aa2b3b..4debba404 100644 --- a/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/TriggerTimeUtilsTest.java +++ b/disjob-supervisor/src/test/java/cn/ponfee/disjob/supervisor/util/TriggerTimeUtilsTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.supervisor.util; diff --git a/disjob-test/src/main/java/cn/ponfee/disjob/test/EmbeddedMysqlAndRedisServer.java b/disjob-test/src/main/java/cn/ponfee/disjob/test/EmbeddedMysqlAndRedisServer.java index 72ebe812e..cae4dc935 100644 --- a/disjob-test/src/main/java/cn/ponfee/disjob/test/EmbeddedMysqlAndRedisServer.java +++ b/disjob-test/src/main/java/cn/ponfee/disjob/test/EmbeddedMysqlAndRedisServer.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.test; diff --git a/disjob-test/src/main/java/cn/ponfee/disjob/test/db/DBUtils.java b/disjob-test/src/main/java/cn/ponfee/disjob/test/db/DBUtils.java index 9393f4acd..3fcdd0ed0 100644 --- a/disjob-test/src/main/java/cn/ponfee/disjob/test/db/DBUtils.java +++ b/disjob-test/src/main/java/cn/ponfee/disjob/test/db/DBUtils.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.test.db; diff --git a/disjob-test/src/main/java/cn/ponfee/disjob/test/db/EmbeddedH2DatabaseServer.java b/disjob-test/src/main/java/cn/ponfee/disjob/test/db/EmbeddedH2DatabaseServer.java index 511800cba..f618f01fd 100644 --- a/disjob-test/src/main/java/cn/ponfee/disjob/test/db/EmbeddedH2DatabaseServer.java +++ b/disjob-test/src/main/java/cn/ponfee/disjob/test/db/EmbeddedH2DatabaseServer.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.test.db; diff --git a/disjob-test/src/main/java/cn/ponfee/disjob/test/db/EmbeddedMysqlServerMariaDB.java b/disjob-test/src/main/java/cn/ponfee/disjob/test/db/EmbeddedMysqlServerMariaDB.java index 0250a4335..afc46ff44 100644 --- a/disjob-test/src/main/java/cn/ponfee/disjob/test/db/EmbeddedMysqlServerMariaDB.java +++ b/disjob-test/src/main/java/cn/ponfee/disjob/test/db/EmbeddedMysqlServerMariaDB.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.test.db; diff --git a/disjob-test/src/main/java/cn/ponfee/disjob/test/db/EmbeddedMysqlServerTestcontainers.java b/disjob-test/src/main/java/cn/ponfee/disjob/test/db/EmbeddedMysqlServerTestcontainers.java index a9014a62e..05585a4f1 100644 --- a/disjob-test/src/main/java/cn/ponfee/disjob/test/db/EmbeddedMysqlServerTestcontainers.java +++ b/disjob-test/src/main/java/cn/ponfee/disjob/test/db/EmbeddedMysqlServerTestcontainers.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.test.db; diff --git a/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/AJobHandler.java b/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/AJobHandler.java index 8401e7cf7..52fd91f04 100644 --- a/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/AJobHandler.java +++ b/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/AJobHandler.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.test.handler; diff --git a/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/BJobHandler.java b/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/BJobHandler.java index abc99ce1d..64fe2b57c 100644 --- a/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/BJobHandler.java +++ b/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/BJobHandler.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.test.handler; diff --git a/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/CJobHandler.java b/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/CJobHandler.java index ded844ce3..108fd9925 100644 --- a/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/CJobHandler.java +++ b/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/CJobHandler.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.test.handler; diff --git a/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/DJobHandler.java b/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/DJobHandler.java index ea7fae3b3..3012b3dbd 100644 --- a/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/DJobHandler.java +++ b/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/DJobHandler.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.test.handler; diff --git a/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/EJobHandler.java b/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/EJobHandler.java index 163c9fab3..0ff30a7e1 100644 --- a/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/EJobHandler.java +++ b/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/EJobHandler.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.test.handler; diff --git a/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/NoopJobHandler.java b/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/NoopJobHandler.java index 9d7b864ed..44a872c98 100644 --- a/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/NoopJobHandler.java +++ b/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/NoopJobHandler.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.test.handler; diff --git a/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/PrimeAccumulateJobHandler.java b/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/PrimeAccumulateJobHandler.java index 79019eafa..15e4ac362 100644 --- a/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/PrimeAccumulateJobHandler.java +++ b/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/PrimeAccumulateJobHandler.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.test.handler; diff --git a/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/PrimeCountJobHandler.java b/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/PrimeCountJobHandler.java index 9bc1ac4c0..4cbbcc1c5 100644 --- a/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/PrimeCountJobHandler.java +++ b/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/PrimeCountJobHandler.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.test.handler; diff --git a/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/TestBroadcastJobHandler.java b/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/TestBroadcastJobHandler.java index 9c84485a2..cb35dad77 100644 --- a/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/TestBroadcastJobHandler.java +++ b/disjob-test/src/main/java/cn/ponfee/disjob/test/handler/TestBroadcastJobHandler.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.test.handler; diff --git a/disjob-test/src/main/java/cn/ponfee/disjob/test/redis/EmbeddedRedisServerKstyrc.java b/disjob-test/src/main/java/cn/ponfee/disjob/test/redis/EmbeddedRedisServerKstyrc.java index 97d5c6968..75f701db5 100644 --- a/disjob-test/src/main/java/cn/ponfee/disjob/test/redis/EmbeddedRedisServerKstyrc.java +++ b/disjob-test/src/main/java/cn/ponfee/disjob/test/redis/EmbeddedRedisServerKstyrc.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.test.redis; diff --git a/disjob-test/src/main/java/cn/ponfee/disjob/test/redis/EmbeddedRedisServerTestcontainers.java b/disjob-test/src/main/java/cn/ponfee/disjob/test/redis/EmbeddedRedisServerTestcontainers.java index d6b287da9..ec14076de 100644 --- a/disjob-test/src/main/java/cn/ponfee/disjob/test/redis/EmbeddedRedisServerTestcontainers.java +++ b/disjob-test/src/main/java/cn/ponfee/disjob/test/redis/EmbeddedRedisServerTestcontainers.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.test.redis; diff --git a/disjob-test/src/main/java/cn/ponfee/disjob/test/util/Constants.java b/disjob-test/src/main/java/cn/ponfee/disjob/test/util/Constants.java index 95db2906a..015928a2c 100644 --- a/disjob-test/src/main/java/cn/ponfee/disjob/test/util/Constants.java +++ b/disjob-test/src/main/java/cn/ponfee/disjob/test/util/Constants.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.test.util; diff --git a/disjob-test/src/main/java/cn/ponfee/disjob/test/util/Prime.java b/disjob-test/src/main/java/cn/ponfee/disjob/test/util/Prime.java index 7a773dd99..bc24b8858 100644 --- a/disjob-test/src/main/java/cn/ponfee/disjob/test/util/Prime.java +++ b/disjob-test/src/main/java/cn/ponfee/disjob/test/util/Prime.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.test.util; diff --git a/disjob-test/src/test/java/cn/ponfee/disjob/test/util/PrimeCountJobHandlerTest.java b/disjob-test/src/test/java/cn/ponfee/disjob/test/util/PrimeCountJobHandlerTest.java index aa992acc2..b11dd3274 100644 --- a/disjob-test/src/test/java/cn/ponfee/disjob/test/util/PrimeCountJobHandlerTest.java +++ b/disjob-test/src/test/java/cn/ponfee/disjob/test/util/PrimeCountJobHandlerTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.test.util; diff --git a/disjob-test/src/test/java/cn/ponfee/disjob/test/util/PrimeTest.java b/disjob-test/src/test/java/cn/ponfee/disjob/test/util/PrimeTest.java index 47f9e4bfc..b93a82307 100644 --- a/disjob-test/src/test/java/cn/ponfee/disjob/test/util/PrimeTest.java +++ b/disjob-test/src/test/java/cn/ponfee/disjob/test/util/PrimeTest.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.test.util; diff --git a/disjob-worker/src/main/java/cn/ponfee/disjob/worker/WorkerStartup.java b/disjob-worker/src/main/java/cn/ponfee/disjob/worker/WorkerStartup.java index 40c7a283c..d4a3fe246 100644 --- a/disjob-worker/src/main/java/cn/ponfee/disjob/worker/WorkerStartup.java +++ b/disjob-worker/src/main/java/cn/ponfee/disjob/worker/WorkerStartup.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.worker; diff --git a/disjob-worker/src/main/java/cn/ponfee/disjob/worker/base/TaskTimingWheel.java b/disjob-worker/src/main/java/cn/ponfee/disjob/worker/base/TaskTimingWheel.java index 9c7c9083b..e92080f56 100644 --- a/disjob-worker/src/main/java/cn/ponfee/disjob/worker/base/TaskTimingWheel.java +++ b/disjob-worker/src/main/java/cn/ponfee/disjob/worker/base/TaskTimingWheel.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.worker.base; diff --git a/disjob-worker/src/main/java/cn/ponfee/disjob/worker/base/TimingWheelRotator.java b/disjob-worker/src/main/java/cn/ponfee/disjob/worker/base/TimingWheelRotator.java index 688c66c7c..6f08273b9 100644 --- a/disjob-worker/src/main/java/cn/ponfee/disjob/worker/base/TimingWheelRotator.java +++ b/disjob-worker/src/main/java/cn/ponfee/disjob/worker/base/TimingWheelRotator.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.worker.base; diff --git a/disjob-worker/src/main/java/cn/ponfee/disjob/worker/base/WorkerConfigurator.java b/disjob-worker/src/main/java/cn/ponfee/disjob/worker/base/WorkerConfigurator.java index 5570905da..af0b6904d 100644 --- a/disjob-worker/src/main/java/cn/ponfee/disjob/worker/base/WorkerConfigurator.java +++ b/disjob-worker/src/main/java/cn/ponfee/disjob/worker/base/WorkerConfigurator.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.worker.base; diff --git a/disjob-worker/src/main/java/cn/ponfee/disjob/worker/base/WorkerThreadPool.java b/disjob-worker/src/main/java/cn/ponfee/disjob/worker/base/WorkerThreadPool.java index d167d3195..05b79fa82 100644 --- a/disjob-worker/src/main/java/cn/ponfee/disjob/worker/base/WorkerThreadPool.java +++ b/disjob-worker/src/main/java/cn/ponfee/disjob/worker/base/WorkerThreadPool.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.worker.base; diff --git a/disjob-worker/src/main/java/cn/ponfee/disjob/worker/configuration/EnableWorker.java b/disjob-worker/src/main/java/cn/ponfee/disjob/worker/configuration/EnableWorker.java index 28e8614f3..197a2ceb5 100644 --- a/disjob-worker/src/main/java/cn/ponfee/disjob/worker/configuration/EnableWorker.java +++ b/disjob-worker/src/main/java/cn/ponfee/disjob/worker/configuration/EnableWorker.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.worker.configuration; diff --git a/disjob-worker/src/main/java/cn/ponfee/disjob/worker/configuration/WorkerLifecycle.java b/disjob-worker/src/main/java/cn/ponfee/disjob/worker/configuration/WorkerLifecycle.java index 6a7b5a4bc..57595fcce 100644 --- a/disjob-worker/src/main/java/cn/ponfee/disjob/worker/configuration/WorkerLifecycle.java +++ b/disjob-worker/src/main/java/cn/ponfee/disjob/worker/configuration/WorkerLifecycle.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.worker.configuration; diff --git a/disjob-worker/src/main/java/cn/ponfee/disjob/worker/configuration/WorkerProperties.java b/disjob-worker/src/main/java/cn/ponfee/disjob/worker/configuration/WorkerProperties.java index bbb4a5201..989838ff4 100644 --- a/disjob-worker/src/main/java/cn/ponfee/disjob/worker/configuration/WorkerProperties.java +++ b/disjob-worker/src/main/java/cn/ponfee/disjob/worker/configuration/WorkerProperties.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.worker.configuration; diff --git a/disjob-worker/src/main/java/cn/ponfee/disjob/worker/provider/WorkerRpcProvider.java b/disjob-worker/src/main/java/cn/ponfee/disjob/worker/provider/WorkerRpcProvider.java index 0273e7faa..08ba89e75 100644 --- a/disjob-worker/src/main/java/cn/ponfee/disjob/worker/provider/WorkerRpcProvider.java +++ b/disjob-worker/src/main/java/cn/ponfee/disjob/worker/provider/WorkerRpcProvider.java @@ -1,10 +1,18 @@ -/* __________ _____ *\ -** \______ \____ _____/ ____\____ ____ Copyright (c) 2017-2023 Ponfee ** -** | ___/ _ \ / \ __\/ __ \_/ __ \ http://www.ponfee.cn ** -** | | ( <_> ) | \ | \ ___/\ ___/ Apache License Version 2.0 ** -** |____| \____/|___| /__| \___ >\___ > http://www.apache.org/licenses/ ** -** \/ \/ \/ ** -\* */ +/* + * Copyright 2022-2024 Ponfee (http://www.ponfee.cn/) + * + * 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 + * + * https://www.apache.org/licenses/LICENSE-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 specific language governing permissions and + * limitations under the License. + */ package cn.ponfee.disjob.worker.provider;