diff --git a/CHANGELOG.md b/CHANGELOG.md index c17a8bda8..e69de29bb 100644 --- a/CHANGELOG.md +++ b/CHANGELOG.md @@ -1,371 +0,0 @@ -Conductor has been upgraded to use the SpringBoot framework and requires Java11 or above. -#### NOTE: The java clients (conductor-client, conductor-client-spring, conductor-grpc-client) are still compiled using Java8 to ensure backward compatibility and smoother migration. - -## Removals/Deprecations -- Removed support for EmbeddedElasticSearch -- Removed deprecated constructors in DynoQueueDAO -- Removed deprecated methods in the Worker interface -- Removed OAuth Support in HTTP task (Looking for contributions for OAuth/OAuth2.0) -- Removed deprecated fields and methods in the Workflow object -- Removed deprecated fields and methods in the Task object -- Removed deprecated fields and methods in the WorkflowTask object - -Removed unused methods from QueueDAO: -- List pop(String, int, int, long) -- List pollMessages(String, int, int, long) - -Removed APIs: -- GET /tasks/in_progress/{tasktype} -- GET /tasks/in_progress/{workflowId}/{taskRefName} -- POST /tasks/{taskId}/ack -- POST /tasks/queue/requeue -- DELETE /queue/{taskType}/{taskId} - - -- GET /event/queues -- GET /event/queues/providers - - -- void restart(String) in workflow client -- List getPendingTasksByType(String, String, Integer) in task client -- Task getPendingTaskForWorkflow(String, String) in task client -- boolean preAck(Task) in Worker -- int getPollCount() in Worker - -## What's changed -Changes to configurations: - -### `azureblob-storage` module: - -| Old | New | Default | -| --- | --- | --- | -| workflow.external.payload.storage.azure_blob.connection_string | conductor.external-payload-storage.azureblob.connectionString | null | -| workflow.external.payload.storage.azure_blob.container_name | conductor.external-payload-storage.azureblob.containerName | conductor-payloads | -| workflow.external.payload.storage.azure_blob.endpoint | conductor.external-payload-storage.azureblob.endpoint | null | -| workflow.external.payload.storage.azure_blob.sas_token | conductor.external-payload-storage.azureblob.sasToken | null | -| workflow.external.payload.storage.azure_blob.signedurlexpirationseconds | conductor.external-payload-storage.azureblob.signedUrlExpirationDuration | 5s | -| workflow.external.payload.storage.azure_blob.workflow_input_path | conductor.external-payload-storage.azureblob.workflowInputPath | workflow/input/ | -| workflow.external.payload.storage.azure_blob.workflow_output_path | conductor.external-payload-storage.azureblob.workflowOutputPath | workflow/output/ | -| workflow.external.payload.storage.azure_blob.task_input_path | conductor.external-payload-storage.azureblob.taskInputPath | task/input/ | -| workflow.external.payload.storage.azure_blob.task_output_path | conductor.external-payload-storage.azureblob.taskOutputPath | task/output/ | - -### `cassandra-persistence` module: - -| Old | New | Default | -| --- | --- | --- | -| workflow.cassandra.host | conductor.cassandra.hostAddress | 127.0.0.1 | -| workflow.cassandra.port | conductor.cassandra.port | 9142 | -| workflow.cassandra.cluster | conductor.cassandra.cluster | "" | -| workflow.cassandra.keyspace | conductor.cassandra.keyspace | conductor | -| workflow.cassandra.shard.size | conductor.cassandra.shardSize | 100 | -| workflow.cassandra.replication.strategy | conductor.cassandra.replicationStrategy | SimpleStrategy | -| workflow.cassandra.replication.factor.key | conductor.cassandra.replicationFactorKey | replication_factor | -| workflow.cassandra.replication.factor.value | conductor.cassandra.replicationFactorValue | 3 | -| workflow.cassandra.read.consistency.level | conductor.cassandra.readConsistencyLevel | LOCAL_QUORUM | -| workflow.cassandra.write.consistency.level | conductor.cassandra.writeConsistencyLevel | LOCAL_QUORUM | -| conductor.taskdef.cache.refresh.time.seconds | conductor.cassandra.taskDefCacheRefreshInterval | 60s | -| conductor.eventhandler.cache.refresh.time.seconds | conductor.cassandra.eventHandlerCacheRefreshInterval | 60s | -| workflow.event.execution.persistence.ttl.seconds | conductor.cassandra.eventExecutionPersistenceTTL | 0s | - -### `contribs` module: - -| Old | New | Default | -| --- | --- | --- | -| workflow.archival.ttl.seconds | conductor.workflow-status-listener.archival.ttlDuration | 0s | -| workflow.archival.delay.queue.worker.thread.count | conductor.workflow-status-listener.archival.delayQueueWorkerThreadCount | 5 | -| workflow.archival.delay.seconds | conductor.workflow-status-listener.archival.delaySeconds | 60 | -| | | -| workflowstatuslistener.publisher.success.queue | conductor.workflow-status-listener.queue-publisher.successQueue | _callbackSuccessQueue | -| workflowstatuslistener.publisher.failure.queue | conductor.workflow-status-listener.queue-publisher.failureQueue | _callbackFailureQueue | -| | | | -| com.netflix.conductor.contribs.metrics.LoggingMetricsModule.reportPeriodSeconds | conductor.metrics-logger.reportInterval | 30s | -| | | | -| workflow.event.queues.amqp.batchSize | conductor.event-queues.amqp.batchSize | 1 | -| workflow.event.queues.amqp.pollTimeInMs | conductor.event-queues.amqp.pollTimeDuration | 100ms | -| workflow.event.queues.amqp.hosts | conductor.event-queues.amqp.hosts | localhost | -| workflow.event.queues.amqp.username | conductor.event-queues.amqp.username | guest | -| workflow.event.queues.amqp.password | conductor.event-queues.amqp.password | guest | -| workflow.event.queues.amqp.virtualHost | conductor.event-queues.amqp.virtualHost | / | -| workflow.event.queues.amqp.port | conductor.event-queues.amqp.port.port | 5672 | -| workflow.event.queues.amqp.connectionTimeout | conductor.event-queues.amqp.connectionTimeout | 60000ms | -| workflow.event.queues.amqp.useNio | conductor.event-queues.amqp.useNio | false | -| workflow.event.queues.amqp.durable | conductor.event-queues.amqp.durable | true | -| workflow.event.queues.amqp.exclusive | conductor.event-queues.amqp.exclusive | false | -| workflow.event.queues.amqp.autoDelete | conductor.event-queues.amqp.autoDelete | false | -| workflow.event.queues.amqp.contentType | conductor.event-queues.amqp.contentType | application/json | -| workflow.event.queues.amqp.contentEncoding | conductor.event-queues.amqp.contentEncoding | UTF-8 | -| workflow.event.queues.amqp.amqp_exchange | conductor.event-queues.amqp.exchangeType | topic | -| workflow.event.queues.amqp.deliveryMode | conductor.event-queues.amqp.deliveryMode | 2 | -| workflow.listener.queue.useExchange | conductor.event-queues.amqp.useExchange | true | -| workflow.listener.queue.prefix | conductor.event-queues.amqp.listenerQueuePrefix | "" | -| | | | -| io.nats.streaming.clusterId | conductor.event-queues.nats-stream.clusterId | test-cluster | -| io.nats.streaming.durableName | conductor.event-queues.nats-stream.durableName | null | -| io.nats.streaming.url | conductor.event-queues.nats-stream.url | nats://localhost:4222 | -| | | | -| workflow.event.queues.sqs.batchSize | conductor.event-queues.sqs.batchSize | 1 | -| workflow.event.queues.sqs.pollTimeInMS | conductor.event-queues.sqs.pollTimeDuration | 100ms | -| workflow.event.queues.sqs.visibilityTimeoutInSeconds | conductor.event-queues.sqs.visibilityTimeout | 60s | -| workflow.listener.queue.prefix | conductor.event-queues.sqs.listenerQueuePrefix | "" | -| workflow.listener.queue.authorizedAccounts | conductor.event-queues.sqs.authorizedAccounts | "" | -| | | | -| workflow.external.payload.storage.s3.bucket | conductor.external-payload-storage.s3.bucketName | conductor_payloads | -| workflow.external.payload.storage.s3.signedurlexpirationseconds | conductor.external-payload-storage.s3.signedUrlExpirationDuration | 5s | -| workflow.external.payload.storage.s3.region | conductor.external-payload-storage.s3.region | us-east-1 | -| | | | -| http.task.read.timeout | conductor.tasks.http.readTimeout | 150ms | -| http.task.connect.timeout | conductor.tasks.http.connectTimeout | 100ms | -| | | | -| kafka.publish.request.timeout.ms | conductor.tasks.kafka-publish.requestTimeout | 100ms | -| kafka.publish.max.block.ms | conductor.tasks.kafka-publish.maxBlock | 500ms | -| kafka.publish.producer.cache.size | conductor.tasks.kafka-publish.cacheSize | 10 | -| kafka.publish.producer.cache.time.ms | conductor.tasks.kafka-publish.cacheTime | 120000ms | - -### `core` module: - -| Old | New | Default | -| --- | --- | --- | -| environment | _removed_ | | -| STACK | conductor.app.stack | test | -| APP_ID | conductor.app.appId | conductor | -| workflow.executor.service.max.threads | conductor.app.executorServiceMaxThreadCount | 50 | -| decider.sweep.frequency.seconds | conductor.app.sweepFrequency | 30s | -| workflow.sweeper.thread.count | conductor.app.sweeperThreadCount | 5 | -| - | conductor.app.sweeperWorkflowPollTimeout | 2000ms | -| workflow.event.processor.thread.count | conductor.app.eventProcessorThreadCount | 2 | -| workflow.event.message.indexing.enabled | conductor.app.eventMessageIndexingEnabled | true | -| workflow.event.execution.indexing.enabled | conductor.app.eventExecutionIndexingEnabled | true | -| workflow.decider.locking.enabled | conductor.app.workflowExecutionLockEnabled | false | -| workflow.locking.lease.time.ms | conductor.app.lockLeaseTime | 60000ms | -| workflow.locking.time.to.try.ms | conductor.app.lockTimeToTry | 500ms | -| tasks.active.worker.lastpoll | conductor.app.activeWorkerLastPollTimeout | 10s | -| task.queue.message.postponeSeconds | conductor.app.taskExecutionPostponeDuration | 60s | -| workflow.taskExecLog.indexing.enabled | conductor.app.taskExecLogIndexingEnabled | true | -| async.indexing.enabled | conductor.app.asyncIndexingEnabled | false | -| workflow.system.task.worker.thread.count | conductor.app.systemTaskWorkerThreadCount | # available processors * 2 | -| workflow.system.task.worker.callback.seconds | conductor.app.systemTaskWorkerCallbackDuration | 30s | -| workflow.system.task.worker.poll.interval | conductor.app.systemTaskWorkerPollInterval | 50s | -| workflow.system.task.worker.executionNameSpace | conductor.app.systemTaskWorkerExecutionNamespace | "" | -| workflow.isolated.system.task.worker.thread.count | conductor.app.isolatedSystemTaskWorkerThreadCount | 1 | -| workflow.system.task.queue.pollCount | conductor.app.systemTaskMaxPollCount | 1 | -| async.update.short.workflow.duration.seconds | conductor.app.asyncUpdateShortRunningWorkflowDuration | 30s | -| async.update.delay.seconds | conductor.app.asyncUpdateDelay | 60s | -| summary.input.output.json.serialization.enabled | conductor.app.summary-input-output-json-serialization.enabled | false | -| workflow.owner.email.mandatory | conductor.app.ownerEmailMandatory | true | -| workflow.repairservice.enabled | conductor.app.workflowRepairServiceEnabled | false | -| workflow.event.queue.scheduler.poll.thread.count | conductor.app.eventSchedulerPollThreadCount | # CPU cores | -| workflow.dyno.queues.pollingInterval | conductor.app.eventQueuePollInterval | 100ms | -| workflow.dyno.queues.pollCount | conductor.app.eventQueuePollCount | 10 | -| workflow.dyno.queues.longPollTimeout | conductor.app.eventQueueLongPollTimeout | 1000ms | -| conductor.workflow.input.payload.threshold.kb | conductor.app.workflowInputPayloadSizeThreshold | 5120KB | -| conductor.max.workflow.input.payload.threshold.kb | conductor.app.maxWorkflowInputPayloadSizeThreshold | 10240KB | -| conductor.workflow.output.payload.threshold.kb | conductor.app.workflowOutputPayloadSizeThreshold | 5120KB | -| conductor.max.workflow.output.payload.threshold.kb | conductor.app.maxWorkflowOutputPayloadSizeThreshold | 10240KB | -| conductor.task.input.payload.threshold.kb | conductor.app.taskInputPayloadSizeThreshold | 3072KB | -| conductor.max.task.input.payload.threshold.kb | conductor.app.maxTaskInputPayloadSizeThreshold | 10240KB | -| conductor.task.output.payload.threshold.kb | conductor.app.taskOutputPayloadSizeThreshold | 3072KB | -| conductor.max.task.output.payload.threshold.kb | conductor.app.maxTaskOutputPayloadSizeThreshold | 10240KB | -| conductor.max.workflow.variables.payload.threshold.kb | conductor.app.maxWorkflowVariablesPayloadSizeThreshold | 256KB | -| | | | -| workflow.isolated.system.task.enable | conductor.app.isolatedSystemTaskEnabled | false | -| workflow.isolated.system.task.poll.time.secs | conductor.app.isolatedSystemTaskQueuePollInterval | 10s | -| | | | -| workflow.task.pending.time.threshold.minutes | conductor.app.taskPendingTimeThreshold | 60m | -| | | | -| workflow.monitor.metadata.refresh.counter | conductor.workflow-monitor.metadataRefreshInterval | 10 | -| workflow.monitor.stats.freq.seconds | conductor.workflow-monitor.statsFrequency | 60s | - -### `es6-persistence` module: - -| Old | New | Default | -| --- | --- | --- | -| workflow.elasticsearch.version | conductor.elasticsearch.version | 6 | -| workflow.elasticsearch.url | conductor.elasticsearch.url | localhost:9300 | -| workflow.elasticsearch.index.name | conductor.elasticsearch.indexPrefix | conductor | -| workflow.elasticsearch.tasklog.index.name | _removed_ | | -| workflow.elasticsearch.cluster.health.color | conductor.elasticsearch.clusterHealthColor | green | -| workflow.elasticsearch.archive.search.batchSize | _removed_ | | -| workflow.elasticsearch.index.batchSize | conductor.elasticsearch.indexBatchSize | 1 | -| workflow.elasticsearch.async.dao.worker.queue.size | conductor.elasticsearch.asyncWorkerQueueSize | 100 | -| workflow.elasticsearch.async.dao.max.pool.size | conductor.elasticsearch.asyncMaxPoolSize | 12 | -| workflow.elasticsearch.async.buffer.flush.timeout.seconds | conductor.elasticsearch.asyncBufferFlushTimeout | 10s | -| workflow.elasticsearch.index.shard.count | conductor.elasticsearch.indexShardCount | 5 | -| workflow.elasticsearch.index.replicas.count | conductor.elasticsearch.indexReplicasCount | 1 | -| tasklog.elasticsearch.query.size | conductor.elasticsearch.taskLogResultLimit | 10 | -| workflow.elasticsearch.rest.client.connectionRequestTimeout.milliseconds | conductor.elasticsearch.restClientConnectionRequestTimeout | -1 | -| workflow.elasticsearch.auto.index.management.enabled | conductor.elasticsearch.autoIndexManagementEnabled | true | -| workflow.elasticsearch.document.type.override | conductor.elasticsearch.documentTypeOverride | "" | - -### `es7-persistence` module: - -| Old | New | Default | -| --- | --- | --- | -| workflow.elasticsearch.version | conductor.elasticsearch.version | 7 | -| workflow.elasticsearch.url | conductor.elasticsearch.url | localhost:9300 | -| workflow.elasticsearch.index.name | conductor.elasticsearch.indexPrefix | conductor | -| workflow.elasticsearch.tasklog.index.name | _removed_ | | -| workflow.elasticsearch.cluster.health.color | conductor.elasticsearch.clusterHealthColor | green | -| workflow.elasticsearch.archive.search.batchSize | _removed_ | | -| workflow.elasticsearch.index.batchSize | conductor.elasticsearch.indexBatchSize | 1 | -| workflow.elasticsearch.async.dao.worker.queue.size | conductor.elasticsearch.asyncWorkerQueueSize | 100 | -| workflow.elasticsearch.async.dao.max.pool.size | conductor.elasticsearch.asyncMaxPoolSize | 12 | -| workflow.elasticsearch.async.buffer.flush.timeout.seconds | conductor.elasticsearch.asyncBufferFlushTimeout | 10s | -| workflow.elasticsearch.index.shard.count | conductor.elasticsearch.indexShardCount | 5 | -| workflow.elasticsearch.index.replicas.count | conductor.elasticsearch.indexReplicasCount | 1 | -| tasklog.elasticsearch.query.size | conductor.elasticsearch.taskLogResultLimit | 10 | -| workflow.elasticsearch.rest.client.connectionRequestTimeout.milliseconds | conductor.elasticsearch.restClientConnectionRequestTimeout | -1 | -| workflow.elasticsearch.auto.index.management.enabled | conductor.elasticsearch.autoIndexManagementEnabled | true | -| workflow.elasticsearch.document.type.override | conductor.elasticsearch.documentTypeOverride | "" | -| workflow.elasticsearch.basic.auth.username | conductor.elasticsearch.username | "" | -| workflow.elasticsearch.basic.auth.password | conductor.elasticsearch.password | "" | - -### `grpc-server` module: - -| Old | New | Default | -| --- | --- | --- | -| conductor.grpc.server.port | conductor.grpc-server.port | 8090 | -| conductor.grpc.server.reflectionEnabled | conductor.grpc-server.reflectionEnabled | true | - -### `mysql-persistence` module (v3.0.0 - v3.0.5): - -| Old | New | Default | -| --- | --- | --- | -| jdbc.url | conductor.mysql.jdbcUrl | jdbc:mysql://localhost:3306/conductor | -| jdbc.username | conductor.mysql.jdbcUsername | conductor | -| jdbc.password | conductor.mysql.jdbcPassword | password | -| flyway.enabled | conductor.mysql.flywayEnabled | true | -| flyway.table | conductor.mysql.flywayTable | null | -| conductor.mysql.connection.pool.size.max | conductor.mysql.connectionPoolMaxSize | -1 | -| conductor.mysql.connection.pool.idle.min | conductor.mysql.connectionPoolMinIdle | -1 | -| conductor.mysql.connection.lifetime.max | conductor.mysql.connectionMaxLifetime | 30m | -| conductor.mysql.connection.idle.timeout | conductor.mysql.connectionIdleTimeout | 10m | -| conductor.mysql.connection.timeout | conductor.mysql.connectionTimeout | 30s | -| conductor.mysql.transaction.isolation.level | conductor.mysql.transactionIsolationLevel | "" | -| conductor.mysql.autocommit | conductor.mysql.autoCommit | false | -| conductor.taskdef.cache.refresh.time.seconds | conductor.mysql.taskDefCacheRefreshInterval | 60s | - -### `mysql-persistence` module (v3.0.5+): - -| Old | New | -| --- | --- | -| jdbc.url | spring.datasource.url | -| jdbc.username | spring.datasource.username | -| jdbc.password | spring.datasource.password | -| flyway.enabled | spring.flyway.enabled | -| flyway.table | spring.flyway.table | -| conductor.mysql.connection.pool.size.max | spring.datasource.hikari.maximum-pool-size | -| conductor.mysql.connection.pool.idle.min | spring.datasource.hikari.minimum-idle | -| conductor.mysql.connection.lifetime.max | spring.datasource.hikari.max-lifetime | -| conductor.mysql.connection.idle.timeout | spring.datasource.hikari.idle-timeout | -| conductor.mysql.connection.timeout | spring.datasource.hikari.connection-timeout | -| conductor.mysql.transaction.isolation.level | spring.datasource.hikari.transaction-isolation | -| conductor.mysql.autocommit | spring.datasource.hikari.auto-commit | -| conductor.taskdef.cache.refresh.time.seconds | conductor.mysql.taskDefCacheRefreshInterval | - -* for more properties and default values: https://docs.spring.io/spring-boot/docs/current/reference/htmlsingle/#application-properties.data.spring.datasource.hikari - -### `postgres-persistence` module (v3.0.0 - v3.0.5): - -| Old | New | Default | -| --- | --- | --- | -| jdbc.url | conductor.postgres.jdbcUrl | jdbc:postgresql://localhost:5432/conductor | -| jdbc.username | conductor.postgres.jdbcUsername | conductor | -| jdbc.password | conductor.postgres.jdbcPassword | password | -| flyway.enabled | conductor.postgres.flywayEnabled | true | -| flyway.table | conductor.postgres.flywayTable | null | -| conductor.postgres.connection.pool.size.max | conductor.postgres.connectionPoolMaxSize | -1 | -| conductor.postgres.connection.pool.idle.min | conductor.postgres.connectionPoolMinIdle | -1 | -| conductor.postgres.connection.lifetime.max | conductor.postgres.connectionMaxLifetime | 30m | -| conductor.postgres.connection.idle.timeout | conductor.postgres.connectionIdleTimeout | 10m | -| conductor.postgres.connection.timeout | conductor.postgres.connectionTimeout | 30s | -| conductor.postgres.transaction.isolation.level | conductor.postgres.transactionIsolationLevel | "" | -| conductor.postgres.autocommit | conductor.postgres.autoCommit | false | -| conductor.taskdef.cache.refresh.time.seconds | conductor.postgres.taskDefCacheRefreshInterval | 60s | - -### `postgres-persistence` module (v3.0.5+): - -| Old | New | -| --- | --- | -| jdbc.url | spring.datasource.url | -| jdbc.username | spring.datasource.username | -| jdbc.password | spring.datasource.password | -| flyway.enabled | spring.flyway.enabled | -| flyway.table | spring.flyway.table | -| conductor.postgres.connection.pool.size.max | spring.datasource.hikari.maximum-pool-size | -| conductor.postgres.connection.pool.idle.min | spring.datasource.hikari.minimum-idle | -| conductor.postgres.connection.lifetime.max | spring.datasource.hikari.max-lifetime | -| conductor.postgres.connection.idle.timeout | spring.datasource.hikari.idle-timeout | -| conductor.postgres.connection.timeout | spring.datasource.hikari.connection-timeout | -| conductor.postgres.transaction.isolation.level | spring.datasource.hikari.transaction-isolation | -| conductor.postgres.autocommit | spring.datasource.hikari.auto-commit | -| conductor.taskdef.cache.refresh.time.seconds | conductor.postgres.taskDefCacheRefreshInterval | - -* for more properties and default values: https://docs.spring.io/spring-boot/docs/current/reference/htmlsingle/#application-properties.data.spring.datasource.hikari - -### `redis-lock` module: - -| Old | New | Default | -| --- | --- | --- | -| workflow.redis.locking.server.type | conductor.redis-lock.serverType | single | -| workflow.redis.locking.server.address | conductor.redis-lock.serverAddress | redis://127.0.0.1:6379 | -| workflow.redis.locking.server.password | conductor.redis-lock.serverPassword | null | -| workflow.redis.locking.server.master.name | conductor.redis-lock.serverMasterName | master | -| workflow.decider.locking.namespace | conductor.redis-lock.namespace | "" | -| workflow.decider.locking.exceptions.ignore | conductor.redis-lock.ignoreLockingExceptions | false | - -### `redis-persistence` module: - -| Old | New | Default | -| --- | --- | --- | -| EC2_REGION | conductor.redis.dataCenterRegion | us-east-1 | -| EC2_AVAILABILITY_ZONE | conductor.redis.availabilityZone | us-east-1c | -| workflow.dynomite.cluster | _removed_ | -| workflow.dynomite.cluster.name | conductor.redis.clusterName | "" | -| workflow.dynomite.cluster.hosts | conductor.redis.hosts | null | -| workflow.namespace.prefix | conductor.redis.workflowNamespacePrefix | null | -| workflow.namespace.queue.prefix | conductor.redis.queueNamespacePrefix | null | -| workflow.dyno.keyspace.domain | conductor.redis.keyspaceDomain | null | -| workflow.dynomite.connection.maxConnsPerHost | conductor.redis.maxConnectionsPerHost | 10 | -| workflow.dynomite.connection.max.retry.attempt | conductor.redis.maxRetryAttempts | 0 | -| workflow.dynomite.connection.max.timeout.exhausted.ms | conductor.redis.maxTimeoutWhenExhausted | 800ms | -| queues.dynomite.nonQuorum.port | conductor.redis.queuesNonQuorumPort | 22122 | -| workflow.dyno.queue.sharding.strategy | conductor.redis.queueShardingStrategy | roundRobin | -| conductor.taskdef.cache.refresh.time.seconds | conductor.redis.taskDefCacheRefreshInterval | 60s | -| workflow.event.execution.persistence.ttl.seconds | conductor.redis.eventExecutionPersistenceTTL | 60s | - -### `zookeeper-lock` module: - -| Old | New | Default | -| --- | --- | --- | -| workflow.zookeeper.lock.connection | conductor.zookeeper-lock.connectionString | localhost:2181 | -| workflow.zookeeper.lock.sessionTimeoutMs | conductor.zookeeper-lock.sessionTimeout | 60000ms | -| workflow.zookeeper.lock.connectionTimeoutMs | conductor.zookeeper-lock.connectionTimeout | 15000ms | -| workflow.decider.locking.namespace | conductor.zookeeper-lock.namespace | "" | - -### Component configuration: - -| Old | New | Default | -| --- | --- | --- | -| db | conductor.db.type | "" | -| workflow.indexing.enabled | conductor.indexing.enabled | true | -| conductor.disable.async.workers | conductor.system-task-workers.enabled | true | -| decider.sweep.disable | conductor.workflow-reconciler.enabled | true | -| conductor.grpc.server.enabled | conductor.grpc-server.enabled | false | -| workflow.external.payload.storage | conductor.external-payload-storage.type | dummy | -| workflow.default.event.processor.enabled | conductor.default-event-processor.enabled | true | -| workflow.events.default.queue.type | conductor.default-event-queue.type | sqs | -| workflow.status.listener.type | conductor.workflow-status-listener.type | stub | -| - | conductor.task-status-listener.type | stub | -| workflow.decider.locking.server | conductor.workflow-execution-lock.type | noop_lock | -| | | | -| workflow.default.event.queue.enabled | conductor.event-queues.default.enabled | true | -| workflow.sqs.event.queue.enabled | conductor.event-queues.sqs.enabled | false | -| workflow.amqp.event.queue.enabled | conductor.event-queues.amqp.enabled | false | -| workflow.nats.event.queue.enabled | conductor.event-queues.nats.enabled | false | -| workflow.nats_stream.event.queue.enabled | conductor.event-queues.nats-stream.enabled | false | -| | | | -| - | conductor.metrics-logger.enabled | false | -| - | conductor.metrics-prometheus.enabled | false | -| - | conductor.metrics-datadog.enable | false | -| - | conductor.metrics-datadog.api-key | | - diff --git a/CODE_OF_CONDUCT.md b/CODE_OF_CONDUCT.md index 425e79778..33d0b4d0a 100644 --- a/CODE_OF_CONDUCT.md +++ b/CODE_OF_CONDUCT.md @@ -1 +1,62 @@ -[Code of Conduct](https://orkes.io/orkes-conductor-community-code-of-conduct) \ No newline at end of file +# Code of Conduct + +Hello valued community members! 👋 + +Our Conductor community has grown tremendously, and as part of ensuring a harmonious experience for everyone, +we've outlined some guidelines that we'd love for all members to uphold. +Our community thrives when everyone engages with kindness, respect, and a collaborative spirit. Here's what we hope to see: + + +### 1. Maintain a Positive Tone. +Every interaction is an opportunity to lift someone up. Let's ensure our words and actions reflect optimism and encouragement. + +### 2. Be Respectful to the Community +Every member here comes with a unique background and perspective. Please honor those differences by being courteous, considerate, and open-minded. +Remember, mutual respect is the foundation of a thriving community. Be careful in the words that you choose. +We are a community of professionals, and we conduct ourselves professionally. +Be kind to others. Do not insult or put down other participants. Harassment and other exclusionary behaviors aren't acceptable. +This includes, but is not limited to: +* Violent threats or language directed against another person Discriminatory jokes and language +* Posting sexualized language or imagery +* Posting (or threatening to post) other people's personally identifying information (“doxing”) +* Personal insults, especially those using racist or sexist terms +* Unwelcome sexual attention +* Advocating for, or encouraging, any of the above behavior +* Repeated harassment of others. In general, if someone asks you to stop, then stop + +### 3. Preserve Our Community's Unity +We understand that as we grow, there might be differing opinions and interests. +However, we kindly request not to create splinter groups or fork out the community. +Let's work through our differences and continue building this space together. + +### 4. Focus on Constructive Discussions +We all have moments of frustration, but let's express ourselves in ways that are constructive. +Avoid comments that could come off as sarcastic, condescending, or disdainful. +Remember, it's always possible to give feedback or express disagreement without belittling others. +We are here to learn from each other and make Conductor the best platform out there. +A big part of that are the exchanges of ideas and approaches that are grounded in data and sound reasoning. +We kindly request that you adhere to that pattern and be thoughtful and responsible in your discussions. +This also means that you are required to have discussions focused on the community and not on promotion of any services, products or goods. + +### 5. When we disagree, try to understand why. +Disagreements, both social and technical, happen all the time and this community is no exception. +It is important that we resolve disagreements and differing views constructively. +Remember that we’re all different. The strength of this community comes from its varied community of people from a wide range of backgrounds. +Different people have different perspectives on issues. Being unable to understand why someone holds a viewpoint doesn’t mean that they’re wrong. +Don’t forget that it is human to err and blaming each other doesn’t get us anywhere. +Instead, focus on helping to resolve issues and learning from mistakes. +Our community's strength lies in our collective spirit. +By following these guidelines, we ensure that our community remains an inspiring, respectful, and welcoming place for everyone. +If you have any concerns or suggestions or if you need to report on any behavior that violates this Code of Conduct, please feel free to reach out to the admins - community@orkes.io. +Let's continue to support and uplift each other! + +### Enforcement +We have a variety of ways of enforcing the code of conduct, including, but not limited to +* Asking you nicely to knock it off +* Asking you less nicely +* Temporary or permanent suspension of the account +* Removal of privileges and/or adding restrictions to the account +* Removal of content +* Banning from the community + +Thank you, \ No newline at end of file diff --git a/CONTRIBUTING.md b/CONTRIBUTING.md index ba24e0019..b102a7a37 100644 --- a/CONTRIBUTING.md +++ b/CONTRIBUTING.md @@ -1 +1,60 @@ -[Contributing](docs/docs/resources/contributing.md) \ No newline at end of file +# Contributing +Thanks for your interest in Conductor! +This guide helps to find the most efficient way to contribute, ask questions, and report issues. + +Code of conduct +----- + +Please review our [Code of Conduct](https://orkes.io/orkes-conductor-community-code-of-conduct) + +I have a question! +----- + +We have a dedicated [discussion forum](https://github.com/conductor-oss/conductor/discussions) for asking "how to" questions and to discuss ideas. The discussion forum is a great place to start if you're considering creating a feature request or work on a Pull Request. +*Please do not create issues to ask questions.* + +Conductor users hangout in the [Slack channel](https://join.slack.com/t/orkes-conductor/shared_invite/zt-xyxqyseb-YZ3hwwAgHJH97bsrYRnSZg). Join the channel for more real-time communication! + +I want to contribute! +------ + +We welcome Pull Requests and already had many outstanding community contributions! +Creating and reviewing Pull Requests take considerable time. This section helps you to set up a smooth Pull Request experience. + +The stable branch is [main](https://github.com/conductor-oss/conductor/tree/main). + +Please create pull requests for your contributions against [main](https://github.com/conductor-oss/conductor/tree/main) only. + +It's a great idea to discuss the new feature you're considering on the [discussion forum](https://github.com/conductor-oss/conductor/discussions) before writing any code. There are often different ways you can implement a feature. Getting some discussion about different options helps shape the best solution. When starting directly with a Pull Request, there is the risk of having to make considerable changes. Sometimes that is the best approach, though! Showing an idea with code can be very helpful; be aware that it might be throw-away work. Some of our best Pull Requests came out of multiple competing implementations, which helped shape it to perfection. + +Also, consider that not every feature is a good fit for Conductor. A few things to consider are: + +* Is it increasing complexity for the user, or might it be confusing? +* Does it, in any way, break backward compatibility (this is seldom acceptable) +* Does it require new dependencies (this is rarely acceptable for core modules) +* Should the feature be opt-in or enabled by default. For integration with a new Queuing recipe or persistence module, a separate module which can be optionally enabled is the right choice. +* Should the feature be implemented in the main Conductor repository, or would it be better to set up a separate repository? Especially for integration with other systems, a separate repository is often the right choice because the life-cycle of it will be different. +* Is it part of the Conductor project roadmap? + +Of course, for more minor bug fixes and improvements, the process can be more light-weight. + +We'll try to be responsive to Pull Requests. Do keep in mind that because of the inherently distributed nature of open source projects, responses to a PR might take some time because of time zones, weekends, and other things we may be working on. + +I want to report an issue +----- + +If you found a bug, it is much appreciated if you create an issue. Please include clear instructions on how to reproduce the issue, or even better, include a test case on a branch. Make sure to come up with a descriptive title for the issue because this helps while organizing issues. + +I have a great idea for a new feature +---- +Many features in Conductor have come from ideas from the community. If you think something is missing or certain use cases could be supported better, let us know! You can do so by opening a discussion on the [discussion forum](https://github.com/conductor-oss/conductor/discussions). Provide as much relevant context to why and when the feature would be helpful. Providing context is especially important for "Support XYZ" issues since we might not be familiar with what "XYZ" is and why it's useful. If you have an idea of how to implement the feature, include that as well. + +Once we have decided on a direction, it's time to summarize the idea by creating a new issue. + +## Code Style +We use [spotless](https://github.com/diffplug/spotless) to enforce consistent code style for the project, so make sure to run `gradlew spotlessApply` to fix any violations after code changes. + +## License +All files are released with the Apache 2.0 license. + + diff --git a/README.md b/README.md index c9525ae62..83b2cbf96 100644 --- a/README.md +++ b/README.md @@ -1,10 +1,10 @@ ![Conductor](docs/docs/img/logo.png) [![Github release](https://img.shields.io/github/v/release/Netflix/conductor.svg)](https://GitHub.com/Netflix/conductor/releases) -[![License](https://img.shields.io/github/license/Netflix/conductor.svg)](http://www.apache.org/licenses/LICENSE-2.0) +[![License](https://img.shields.io/github/license/conductor-oss/conductor.svg)](http://www.apache.org/licenses/LICENSE-2.0) -Conductor is a platform originally created at Netflix to orchestrate microservices and events. +Conductor is a platform _originally_ created at Netflix to orchestrate microservices and events. Conductor OSS is maintained by the team of developers at [Orkes](https://orkes.io/) along with the members of the open source community. ## Conductor OSS @@ -13,7 +13,7 @@ This is the new home for the Conductor open source going forward (previously hos > Going forward, all the bug fixes, feature requests and security patches will be applied and released from this repository. -The last published version of Netflix Condutor will be **3.15.0** which we will continue to support. +The last published version of Netflix Conductor will be **3.15.0** which we will continue to support. If you would like to participate in the roadmap and development, [please reach out](https://forms.gle/P2i1xHrxPQLrjzTB7). diff --git a/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/AMQPConnection.java b/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/AMQPConnection.java index c308d1593..d5839539a 100644 --- a/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/AMQPConnection.java +++ b/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/AMQPConnection.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/AMQPObservableQueue.java b/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/AMQPObservableQueue.java index 15d33f09d..c71850eb0 100644 --- a/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/AMQPObservableQueue.java +++ b/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/AMQPObservableQueue.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/config/AMQPEventQueueConfiguration.java b/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/config/AMQPEventQueueConfiguration.java index b23b64fe0..a4e23d232 100644 --- a/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/config/AMQPEventQueueConfiguration.java +++ b/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/config/AMQPEventQueueConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/config/AMQPEventQueueProperties.java b/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/config/AMQPEventQueueProperties.java index ac0a08dae..bbf3aab9c 100644 --- a/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/config/AMQPEventQueueProperties.java +++ b/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/config/AMQPEventQueueProperties.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/config/AMQPEventQueueProvider.java b/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/config/AMQPEventQueueProvider.java index 51bcc4082..6e17ef8ef 100644 --- a/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/config/AMQPEventQueueProvider.java +++ b/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/config/AMQPEventQueueProvider.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/config/AMQPRetryPattern.java b/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/config/AMQPRetryPattern.java index 736cb5f42..6d9d159a5 100644 --- a/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/config/AMQPRetryPattern.java +++ b/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/config/AMQPRetryPattern.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/util/AMQPConfigurations.java b/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/util/AMQPConfigurations.java index 36bd7a6cf..d0d3b93c5 100644 --- a/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/util/AMQPConfigurations.java +++ b/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/util/AMQPConfigurations.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/util/AMQPConstants.java b/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/util/AMQPConstants.java index fc9aa9892..3abd619bf 100644 --- a/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/util/AMQPConstants.java +++ b/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/util/AMQPConstants.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/util/AMQPSettings.java b/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/util/AMQPSettings.java index 4684d16a3..db18dd9df 100644 --- a/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/util/AMQPSettings.java +++ b/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/util/AMQPSettings.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/util/ConnectionType.java b/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/util/ConnectionType.java index c6cfdc273..0b28ce273 100644 --- a/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/util/ConnectionType.java +++ b/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/util/ConnectionType.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/util/RetryType.java b/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/util/RetryType.java index 00c683527..192c49f25 100644 --- a/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/util/RetryType.java +++ b/amqp/src/main/java/com/netflix/conductor/contribs/queue/amqp/util/RetryType.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/amqp/src/test/java/com/netflix/conductor/contribs/queue/amqp/AMQPEventQueueProviderTest.java b/amqp/src/test/java/com/netflix/conductor/contribs/queue/amqp/AMQPEventQueueProviderTest.java index b881e4cc1..2ca8a781a 100644 --- a/amqp/src/test/java/com/netflix/conductor/contribs/queue/amqp/AMQPEventQueueProviderTest.java +++ b/amqp/src/test/java/com/netflix/conductor/contribs/queue/amqp/AMQPEventQueueProviderTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/amqp/src/test/java/com/netflix/conductor/contribs/queue/amqp/AMQPObservableQueueTest.java b/amqp/src/test/java/com/netflix/conductor/contribs/queue/amqp/AMQPObservableQueueTest.java index 9a16cae64..1b6139a4a 100644 --- a/amqp/src/test/java/com/netflix/conductor/contribs/queue/amqp/AMQPObservableQueueTest.java +++ b/amqp/src/test/java/com/netflix/conductor/contribs/queue/amqp/AMQPObservableQueueTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/amqp/src/test/java/com/netflix/conductor/contribs/queue/amqp/AMQPSettingsTest.java b/amqp/src/test/java/com/netflix/conductor/contribs/queue/amqp/AMQPSettingsTest.java index 7b9f60e1f..a9c5f26f0 100644 --- a/amqp/src/test/java/com/netflix/conductor/contribs/queue/amqp/AMQPSettingsTest.java +++ b/amqp/src/test/java/com/netflix/conductor/contribs/queue/amqp/AMQPSettingsTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/annotations-processor/src/example/java/com/example/Example.java b/annotations-processor/src/example/java/com/example/Example.java index b3c7befe8..f55cfac6e 100644 --- a/annotations-processor/src/example/java/com/example/Example.java +++ b/annotations-processor/src/example/java/com/example/Example.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/AbstractMessage.java b/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/AbstractMessage.java index bc92d901f..3794a7ca0 100644 --- a/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/AbstractMessage.java +++ b/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/AbstractMessage.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/Enum.java b/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/Enum.java index 3944bafb1..d1b4564bd 100644 --- a/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/Enum.java +++ b/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/Enum.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/Message.java b/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/Message.java index 9dfaf2883..ba6b1122b 100644 --- a/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/Message.java +++ b/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/Message.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/ProtoFile.java b/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/ProtoFile.java index 1bd543a60..e562c0f88 100644 --- a/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/ProtoFile.java +++ b/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/ProtoFile.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/ProtoGen.java b/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/ProtoGen.java index e694918c3..a2716eb3f 100644 --- a/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/ProtoGen.java +++ b/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/ProtoGen.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/ProtoGenTask.java b/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/ProtoGenTask.java index fb411fc4f..d161d6ffb 100644 --- a/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/ProtoGenTask.java +++ b/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/ProtoGenTask.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/AbstractType.java b/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/AbstractType.java index fbfa8e72c..6a38fd551 100644 --- a/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/AbstractType.java +++ b/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/AbstractType.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/ExternMessageType.java b/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/ExternMessageType.java index ed7eaae24..93279d515 100644 --- a/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/ExternMessageType.java +++ b/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/ExternMessageType.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/GenericType.java b/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/GenericType.java index 5bad20a2f..adf8f4d8f 100644 --- a/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/GenericType.java +++ b/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/GenericType.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/ListType.java b/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/ListType.java index 921594391..50bbf1c7e 100644 --- a/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/ListType.java +++ b/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/ListType.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/MapType.java b/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/MapType.java index fe642fdec..bdcb5bfe0 100644 --- a/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/MapType.java +++ b/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/MapType.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/MessageType.java b/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/MessageType.java index d57228773..724817af8 100644 --- a/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/MessageType.java +++ b/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/MessageType.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/ScalarType.java b/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/ScalarType.java index c6958bdd9..afefc788e 100644 --- a/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/ScalarType.java +++ b/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/ScalarType.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/TypeMapper.java b/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/TypeMapper.java index 2363ed365..7e997098f 100644 --- a/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/TypeMapper.java +++ b/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/TypeMapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/WrappedType.java b/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/WrappedType.java index c6d04e172..409e47dfa 100644 --- a/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/WrappedType.java +++ b/annotations-processor/src/main/java/com/netflix/conductor/annotationsprocessor/protogen/types/WrappedType.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/annotations-processor/src/test/java/com/netflix/conductor/annotationsprocessor/protogen/ProtoGenTest.java b/annotations-processor/src/test/java/com/netflix/conductor/annotationsprocessor/protogen/ProtoGenTest.java index 0fe7a243b..09f637215 100644 --- a/annotations-processor/src/test/java/com/netflix/conductor/annotationsprocessor/protogen/ProtoGenTest.java +++ b/annotations-processor/src/test/java/com/netflix/conductor/annotationsprocessor/protogen/ProtoGenTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/annotations/src/main/java/com/netflix/conductor/annotations/protogen/ProtoEnum.java b/annotations/src/main/java/com/netflix/conductor/annotations/protogen/ProtoEnum.java index 1514a3ed8..c07e679f7 100644 --- a/annotations/src/main/java/com/netflix/conductor/annotations/protogen/ProtoEnum.java +++ b/annotations/src/main/java/com/netflix/conductor/annotations/protogen/ProtoEnum.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/annotations/src/main/java/com/netflix/conductor/annotations/protogen/ProtoField.java b/annotations/src/main/java/com/netflix/conductor/annotations/protogen/ProtoField.java index 25ab478c8..a61bb5ea1 100644 --- a/annotations/src/main/java/com/netflix/conductor/annotations/protogen/ProtoField.java +++ b/annotations/src/main/java/com/netflix/conductor/annotations/protogen/ProtoField.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/annotations/src/main/java/com/netflix/conductor/annotations/protogen/ProtoMessage.java b/annotations/src/main/java/com/netflix/conductor/annotations/protogen/ProtoMessage.java index d66e4aa43..45fa884f9 100644 --- a/annotations/src/main/java/com/netflix/conductor/annotations/protogen/ProtoMessage.java +++ b/annotations/src/main/java/com/netflix/conductor/annotations/protogen/ProtoMessage.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/awss3-storage/src/main/java/com/netflix/conductor/s3/config/S3Configuration.java b/awss3-storage/src/main/java/com/netflix/conductor/s3/config/S3Configuration.java index 5b8e6b3dc..b14d79395 100644 --- a/awss3-storage/src/main/java/com/netflix/conductor/s3/config/S3Configuration.java +++ b/awss3-storage/src/main/java/com/netflix/conductor/s3/config/S3Configuration.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/awss3-storage/src/main/java/com/netflix/conductor/s3/config/S3Properties.java b/awss3-storage/src/main/java/com/netflix/conductor/s3/config/S3Properties.java index 94a515f72..9c41b4a10 100644 --- a/awss3-storage/src/main/java/com/netflix/conductor/s3/config/S3Properties.java +++ b/awss3-storage/src/main/java/com/netflix/conductor/s3/config/S3Properties.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/awss3-storage/src/main/java/com/netflix/conductor/s3/storage/S3PayloadStorage.java b/awss3-storage/src/main/java/com/netflix/conductor/s3/storage/S3PayloadStorage.java index 838ab4088..19ac68d27 100644 --- a/awss3-storage/src/main/java/com/netflix/conductor/s3/storage/S3PayloadStorage.java +++ b/awss3-storage/src/main/java/com/netflix/conductor/s3/storage/S3PayloadStorage.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/awssqs-event-queue/src/main/java/com/netflix/conductor/sqs/config/SQSEventQueueConfiguration.java b/awssqs-event-queue/src/main/java/com/netflix/conductor/sqs/config/SQSEventQueueConfiguration.java index fb3065895..1f4165423 100644 --- a/awssqs-event-queue/src/main/java/com/netflix/conductor/sqs/config/SQSEventQueueConfiguration.java +++ b/awssqs-event-queue/src/main/java/com/netflix/conductor/sqs/config/SQSEventQueueConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/awssqs-event-queue/src/main/java/com/netflix/conductor/sqs/config/SQSEventQueueProperties.java b/awssqs-event-queue/src/main/java/com/netflix/conductor/sqs/config/SQSEventQueueProperties.java index 4bd9eb9ba..fbe40eea9 100644 --- a/awssqs-event-queue/src/main/java/com/netflix/conductor/sqs/config/SQSEventQueueProperties.java +++ b/awssqs-event-queue/src/main/java/com/netflix/conductor/sqs/config/SQSEventQueueProperties.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/awssqs-event-queue/src/main/java/com/netflix/conductor/sqs/config/SQSEventQueueProvider.java b/awssqs-event-queue/src/main/java/com/netflix/conductor/sqs/config/SQSEventQueueProvider.java index 2d0b45e21..425012086 100644 --- a/awssqs-event-queue/src/main/java/com/netflix/conductor/sqs/config/SQSEventQueueProvider.java +++ b/awssqs-event-queue/src/main/java/com/netflix/conductor/sqs/config/SQSEventQueueProvider.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/awssqs-event-queue/src/main/java/com/netflix/conductor/sqs/eventqueue/SQSObservableQueue.java b/awssqs-event-queue/src/main/java/com/netflix/conductor/sqs/eventqueue/SQSObservableQueue.java index 95a1771b7..5f3e4173b 100644 --- a/awssqs-event-queue/src/main/java/com/netflix/conductor/sqs/eventqueue/SQSObservableQueue.java +++ b/awssqs-event-queue/src/main/java/com/netflix/conductor/sqs/eventqueue/SQSObservableQueue.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/awssqs-event-queue/src/test/java/com/netflix/conductor/sqs/eventqueue/DefaultEventQueueProcessorTest.java b/awssqs-event-queue/src/test/java/com/netflix/conductor/sqs/eventqueue/DefaultEventQueueProcessorTest.java index ab7be3118..1607acf44 100644 --- a/awssqs-event-queue/src/test/java/com/netflix/conductor/sqs/eventqueue/DefaultEventQueueProcessorTest.java +++ b/awssqs-event-queue/src/test/java/com/netflix/conductor/sqs/eventqueue/DefaultEventQueueProcessorTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/awssqs-event-queue/src/test/java/com/netflix/conductor/sqs/eventqueue/SQSObservableQueueTest.java b/awssqs-event-queue/src/test/java/com/netflix/conductor/sqs/eventqueue/SQSObservableQueueTest.java index 7c0d69aa5..39acc6f54 100644 --- a/awssqs-event-queue/src/test/java/com/netflix/conductor/sqs/eventqueue/SQSObservableQueueTest.java +++ b/awssqs-event-queue/src/test/java/com/netflix/conductor/sqs/eventqueue/SQSObservableQueueTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/azureblob-storage/src/main/java/com/netflix/conductor/azureblob/config/AzureBlobConfiguration.java b/azureblob-storage/src/main/java/com/netflix/conductor/azureblob/config/AzureBlobConfiguration.java index 476ad1dad..49c0a2f68 100644 --- a/azureblob-storage/src/main/java/com/netflix/conductor/azureblob/config/AzureBlobConfiguration.java +++ b/azureblob-storage/src/main/java/com/netflix/conductor/azureblob/config/AzureBlobConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/azureblob-storage/src/main/java/com/netflix/conductor/azureblob/config/AzureBlobProperties.java b/azureblob-storage/src/main/java/com/netflix/conductor/azureblob/config/AzureBlobProperties.java index cb5450923..3932bd677 100644 --- a/azureblob-storage/src/main/java/com/netflix/conductor/azureblob/config/AzureBlobProperties.java +++ b/azureblob-storage/src/main/java/com/netflix/conductor/azureblob/config/AzureBlobProperties.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/azureblob-storage/src/main/java/com/netflix/conductor/azureblob/storage/AzureBlobPayloadStorage.java b/azureblob-storage/src/main/java/com/netflix/conductor/azureblob/storage/AzureBlobPayloadStorage.java index 4ad51fb33..6d1ead96d 100644 --- a/azureblob-storage/src/main/java/com/netflix/conductor/azureblob/storage/AzureBlobPayloadStorage.java +++ b/azureblob-storage/src/main/java/com/netflix/conductor/azureblob/storage/AzureBlobPayloadStorage.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/azureblob-storage/src/test/java/com/netflix/conductor/azureblob/storage/AzureBlobPayloadStorageTest.java b/azureblob-storage/src/test/java/com/netflix/conductor/azureblob/storage/AzureBlobPayloadStorageTest.java index b5fb30aee..2935f609d 100644 --- a/azureblob-storage/src/test/java/com/netflix/conductor/azureblob/storage/AzureBlobPayloadStorageTest.java +++ b/azureblob-storage/src/test/java/com/netflix/conductor/azureblob/storage/AzureBlobPayloadStorageTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/config/CassandraConfiguration.java b/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/config/CassandraConfiguration.java index 14c3c022b..f415aa55f 100644 --- a/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/config/CassandraConfiguration.java +++ b/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/config/CassandraConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/config/CassandraProperties.java b/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/config/CassandraProperties.java index 28d3eee97..37ca274de 100644 --- a/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/config/CassandraProperties.java +++ b/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/config/CassandraProperties.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/config/cache/CacheableEventHandlerDAO.java b/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/config/cache/CacheableEventHandlerDAO.java index fabfd3c55..4973e811e 100644 --- a/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/config/cache/CacheableEventHandlerDAO.java +++ b/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/config/cache/CacheableEventHandlerDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/config/cache/CacheableMetadataDAO.java b/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/config/cache/CacheableMetadataDAO.java index 2facedbd0..7ccdeb96a 100644 --- a/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/config/cache/CacheableMetadataDAO.java +++ b/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/config/cache/CacheableMetadataDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/config/cache/CachingConfig.java b/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/config/cache/CachingConfig.java index bd0f178f5..6255ce47e 100644 --- a/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/config/cache/CachingConfig.java +++ b/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/config/cache/CachingConfig.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/dao/CassandraBaseDAO.java b/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/dao/CassandraBaseDAO.java index b327c18fb..e6fb4b27a 100644 --- a/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/dao/CassandraBaseDAO.java +++ b/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/dao/CassandraBaseDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/dao/CassandraEventHandlerDAO.java b/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/dao/CassandraEventHandlerDAO.java index 4fa72a2ea..db6e1fadf 100644 --- a/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/dao/CassandraEventHandlerDAO.java +++ b/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/dao/CassandraEventHandlerDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/dao/CassandraExecutionDAO.java b/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/dao/CassandraExecutionDAO.java index ce564af0a..6ced38b8d 100644 --- a/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/dao/CassandraExecutionDAO.java +++ b/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/dao/CassandraExecutionDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/dao/CassandraMetadataDAO.java b/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/dao/CassandraMetadataDAO.java index 90ff3ed4a..9c6de6438 100644 --- a/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/dao/CassandraMetadataDAO.java +++ b/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/dao/CassandraMetadataDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/dao/CassandraPollDataDAO.java b/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/dao/CassandraPollDataDAO.java index 235dd44f4..8e7e4d1e3 100644 --- a/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/dao/CassandraPollDataDAO.java +++ b/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/dao/CassandraPollDataDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/util/Constants.java b/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/util/Constants.java index 473c23132..1d815ae62 100644 --- a/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/util/Constants.java +++ b/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/util/Constants.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/util/Statements.java b/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/util/Statements.java index 68fe3b242..63e6b4a06 100644 --- a/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/util/Statements.java +++ b/cassandra-persistence/src/main/java/com/netflix/conductor/cassandra/util/Statements.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/cassandra-persistence/src/test/groovy/com/netflix/conductor/cassandra/dao/CassandraEventHandlerDAOSpec.groovy b/cassandra-persistence/src/test/groovy/com/netflix/conductor/cassandra/dao/CassandraEventHandlerDAOSpec.groovy index 214f3722d..e0d437d7b 100644 --- a/cassandra-persistence/src/test/groovy/com/netflix/conductor/cassandra/dao/CassandraEventHandlerDAOSpec.groovy +++ b/cassandra-persistence/src/test/groovy/com/netflix/conductor/cassandra/dao/CassandraEventHandlerDAOSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/cassandra-persistence/src/test/groovy/com/netflix/conductor/cassandra/dao/CassandraExecutionDAOSpec.groovy b/cassandra-persistence/src/test/groovy/com/netflix/conductor/cassandra/dao/CassandraExecutionDAOSpec.groovy index 14f612967..13e79e238 100644 --- a/cassandra-persistence/src/test/groovy/com/netflix/conductor/cassandra/dao/CassandraExecutionDAOSpec.groovy +++ b/cassandra-persistence/src/test/groovy/com/netflix/conductor/cassandra/dao/CassandraExecutionDAOSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/cassandra-persistence/src/test/groovy/com/netflix/conductor/cassandra/dao/CassandraMetadataDAOSpec.groovy b/cassandra-persistence/src/test/groovy/com/netflix/conductor/cassandra/dao/CassandraMetadataDAOSpec.groovy index fd8afacc5..498435cdc 100644 --- a/cassandra-persistence/src/test/groovy/com/netflix/conductor/cassandra/dao/CassandraMetadataDAOSpec.groovy +++ b/cassandra-persistence/src/test/groovy/com/netflix/conductor/cassandra/dao/CassandraMetadataDAOSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/cassandra-persistence/src/test/groovy/com/netflix/conductor/cassandra/dao/CassandraSpec.groovy b/cassandra-persistence/src/test/groovy/com/netflix/conductor/cassandra/dao/CassandraSpec.groovy index a5393210b..935788e89 100644 --- a/cassandra-persistence/src/test/groovy/com/netflix/conductor/cassandra/dao/CassandraSpec.groovy +++ b/cassandra-persistence/src/test/groovy/com/netflix/conductor/cassandra/dao/CassandraSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/cassandra-persistence/src/test/groovy/com/netflix/conductor/cassandra/util/StatementsSpec.groovy b/cassandra-persistence/src/test/groovy/com/netflix/conductor/cassandra/util/StatementsSpec.groovy index f826a3620..8517e7e4a 100644 --- a/cassandra-persistence/src/test/groovy/com/netflix/conductor/cassandra/util/StatementsSpec.groovy +++ b/cassandra-persistence/src/test/groovy/com/netflix/conductor/cassandra/util/StatementsSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client-spring/src/main/java/com/netflix/conductor/client/spring/ClientProperties.java b/client-spring/src/main/java/com/netflix/conductor/client/spring/ClientProperties.java index 55c82e576..87b13cbfe 100644 --- a/client-spring/src/main/java/com/netflix/conductor/client/spring/ClientProperties.java +++ b/client-spring/src/main/java/com/netflix/conductor/client/spring/ClientProperties.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client-spring/src/main/java/com/netflix/conductor/client/spring/ConductorClientAutoConfiguration.java b/client-spring/src/main/java/com/netflix/conductor/client/spring/ConductorClientAutoConfiguration.java index a730f24eb..0219edbf1 100644 --- a/client-spring/src/main/java/com/netflix/conductor/client/spring/ConductorClientAutoConfiguration.java +++ b/client-spring/src/main/java/com/netflix/conductor/client/spring/ConductorClientAutoConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client-spring/src/main/java/com/netflix/conductor/client/spring/ConductorWorkerAutoConfiguration.java b/client-spring/src/main/java/com/netflix/conductor/client/spring/ConductorWorkerAutoConfiguration.java index 94d69bbde..dd6983f33 100644 --- a/client-spring/src/main/java/com/netflix/conductor/client/spring/ConductorWorkerAutoConfiguration.java +++ b/client-spring/src/main/java/com/netflix/conductor/client/spring/ConductorWorkerAutoConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client-spring/src/main/java/com/netflix/conductor/client/spring/SpringWorkerConfiguration.java b/client-spring/src/main/java/com/netflix/conductor/client/spring/SpringWorkerConfiguration.java index 6d44e779c..231bf92e4 100644 --- a/client-spring/src/main/java/com/netflix/conductor/client/spring/SpringWorkerConfiguration.java +++ b/client-spring/src/main/java/com/netflix/conductor/client/spring/SpringWorkerConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client-spring/src/test/java/com/netflix/conductor/client/spring/ExampleClient.java b/client-spring/src/test/java/com/netflix/conductor/client/spring/ExampleClient.java index 772c04dc0..4bca46e97 100644 --- a/client-spring/src/test/java/com/netflix/conductor/client/spring/ExampleClient.java +++ b/client-spring/src/test/java/com/netflix/conductor/client/spring/ExampleClient.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client-spring/src/test/java/com/netflix/conductor/client/spring/Workers.java b/client-spring/src/test/java/com/netflix/conductor/client/spring/Workers.java index d28bf0c8d..8f1fb1a44 100644 --- a/client-spring/src/test/java/com/netflix/conductor/client/spring/Workers.java +++ b/client-spring/src/test/java/com/netflix/conductor/client/spring/Workers.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/main/java/com/netflix/conductor/client/automator/PollingSemaphore.java b/client/src/main/java/com/netflix/conductor/client/automator/PollingSemaphore.java index 334501fac..c4304c2d5 100644 --- a/client/src/main/java/com/netflix/conductor/client/automator/PollingSemaphore.java +++ b/client/src/main/java/com/netflix/conductor/client/automator/PollingSemaphore.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/main/java/com/netflix/conductor/client/automator/TaskPollExecutor.java b/client/src/main/java/com/netflix/conductor/client/automator/TaskPollExecutor.java index 3b011c93d..b0cb46c53 100644 --- a/client/src/main/java/com/netflix/conductor/client/automator/TaskPollExecutor.java +++ b/client/src/main/java/com/netflix/conductor/client/automator/TaskPollExecutor.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/main/java/com/netflix/conductor/client/automator/TaskRunnerConfigurer.java b/client/src/main/java/com/netflix/conductor/client/automator/TaskRunnerConfigurer.java index 3709f2aa5..3f740e6e4 100644 --- a/client/src/main/java/com/netflix/conductor/client/automator/TaskRunnerConfigurer.java +++ b/client/src/main/java/com/netflix/conductor/client/automator/TaskRunnerConfigurer.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/main/java/com/netflix/conductor/client/config/ConductorClientConfiguration.java b/client/src/main/java/com/netflix/conductor/client/config/ConductorClientConfiguration.java index 6c3029fa1..bb5a28926 100644 --- a/client/src/main/java/com/netflix/conductor/client/config/ConductorClientConfiguration.java +++ b/client/src/main/java/com/netflix/conductor/client/config/ConductorClientConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2018 Netflix, Inc. + * Copyright 2018 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/main/java/com/netflix/conductor/client/config/DefaultConductorClientConfiguration.java b/client/src/main/java/com/netflix/conductor/client/config/DefaultConductorClientConfiguration.java index f15cf3bab..13e7f3247 100644 --- a/client/src/main/java/com/netflix/conductor/client/config/DefaultConductorClientConfiguration.java +++ b/client/src/main/java/com/netflix/conductor/client/config/DefaultConductorClientConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/main/java/com/netflix/conductor/client/config/PropertyFactory.java b/client/src/main/java/com/netflix/conductor/client/config/PropertyFactory.java index 443b85481..dcde89a37 100644 --- a/client/src/main/java/com/netflix/conductor/client/config/PropertyFactory.java +++ b/client/src/main/java/com/netflix/conductor/client/config/PropertyFactory.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/main/java/com/netflix/conductor/client/exception/ConductorClientException.java b/client/src/main/java/com/netflix/conductor/client/exception/ConductorClientException.java index 5f3c79c00..a2af3a06b 100644 --- a/client/src/main/java/com/netflix/conductor/client/exception/ConductorClientException.java +++ b/client/src/main/java/com/netflix/conductor/client/exception/ConductorClientException.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/main/java/com/netflix/conductor/client/http/ClientBase.java b/client/src/main/java/com/netflix/conductor/client/http/ClientBase.java index a27da869d..5326abe4d 100644 --- a/client/src/main/java/com/netflix/conductor/client/http/ClientBase.java +++ b/client/src/main/java/com/netflix/conductor/client/http/ClientBase.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/main/java/com/netflix/conductor/client/http/ClientRequestHandler.java b/client/src/main/java/com/netflix/conductor/client/http/ClientRequestHandler.java index 38749c1c5..164cb579b 100644 --- a/client/src/main/java/com/netflix/conductor/client/http/ClientRequestHandler.java +++ b/client/src/main/java/com/netflix/conductor/client/http/ClientRequestHandler.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/main/java/com/netflix/conductor/client/http/EventClient.java b/client/src/main/java/com/netflix/conductor/client/http/EventClient.java index 660c2b44a..1782d0177 100644 --- a/client/src/main/java/com/netflix/conductor/client/http/EventClient.java +++ b/client/src/main/java/com/netflix/conductor/client/http/EventClient.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/main/java/com/netflix/conductor/client/http/MetadataClient.java b/client/src/main/java/com/netflix/conductor/client/http/MetadataClient.java index 8db927b8c..2db8df237 100644 --- a/client/src/main/java/com/netflix/conductor/client/http/MetadataClient.java +++ b/client/src/main/java/com/netflix/conductor/client/http/MetadataClient.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/main/java/com/netflix/conductor/client/http/PayloadStorage.java b/client/src/main/java/com/netflix/conductor/client/http/PayloadStorage.java index 0b05745f0..668e50047 100644 --- a/client/src/main/java/com/netflix/conductor/client/http/PayloadStorage.java +++ b/client/src/main/java/com/netflix/conductor/client/http/PayloadStorage.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/main/java/com/netflix/conductor/client/http/TaskClient.java b/client/src/main/java/com/netflix/conductor/client/http/TaskClient.java index d624ef0f6..35d48b2e3 100644 --- a/client/src/main/java/com/netflix/conductor/client/http/TaskClient.java +++ b/client/src/main/java/com/netflix/conductor/client/http/TaskClient.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/main/java/com/netflix/conductor/client/http/WorkflowClient.java b/client/src/main/java/com/netflix/conductor/client/http/WorkflowClient.java index 6bfa686bb..14deabff3 100644 --- a/client/src/main/java/com/netflix/conductor/client/http/WorkflowClient.java +++ b/client/src/main/java/com/netflix/conductor/client/http/WorkflowClient.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/main/java/com/netflix/conductor/client/telemetry/MetricsContainer.java b/client/src/main/java/com/netflix/conductor/client/telemetry/MetricsContainer.java index 7b9bb0ca3..d80349ff9 100644 --- a/client/src/main/java/com/netflix/conductor/client/telemetry/MetricsContainer.java +++ b/client/src/main/java/com/netflix/conductor/client/telemetry/MetricsContainer.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/main/java/com/netflix/conductor/client/worker/Worker.java b/client/src/main/java/com/netflix/conductor/client/worker/Worker.java index 9f07b151c..5b0ecc0b1 100644 --- a/client/src/main/java/com/netflix/conductor/client/worker/Worker.java +++ b/client/src/main/java/com/netflix/conductor/client/worker/Worker.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/test/groovy/com/netflix/conductor/client/http/ClientSpecification.groovy b/client/src/test/groovy/com/netflix/conductor/client/http/ClientSpecification.groovy index 5c4a5208d..c804f785c 100644 --- a/client/src/test/groovy/com/netflix/conductor/client/http/ClientSpecification.groovy +++ b/client/src/test/groovy/com/netflix/conductor/client/http/ClientSpecification.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/test/groovy/com/netflix/conductor/client/http/EventClientSpec.groovy b/client/src/test/groovy/com/netflix/conductor/client/http/EventClientSpec.groovy index f4f32a767..bb121c56d 100644 --- a/client/src/test/groovy/com/netflix/conductor/client/http/EventClientSpec.groovy +++ b/client/src/test/groovy/com/netflix/conductor/client/http/EventClientSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/test/groovy/com/netflix/conductor/client/http/MetadataClientSpec.groovy b/client/src/test/groovy/com/netflix/conductor/client/http/MetadataClientSpec.groovy index d82acc509..13790d3fc 100644 --- a/client/src/test/groovy/com/netflix/conductor/client/http/MetadataClientSpec.groovy +++ b/client/src/test/groovy/com/netflix/conductor/client/http/MetadataClientSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/test/groovy/com/netflix/conductor/client/http/TaskClientSpec.groovy b/client/src/test/groovy/com/netflix/conductor/client/http/TaskClientSpec.groovy index bf21d8107..2caba4490 100644 --- a/client/src/test/groovy/com/netflix/conductor/client/http/TaskClientSpec.groovy +++ b/client/src/test/groovy/com/netflix/conductor/client/http/TaskClientSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/test/groovy/com/netflix/conductor/client/http/WorkflowClientSpec.groovy b/client/src/test/groovy/com/netflix/conductor/client/http/WorkflowClientSpec.groovy index 08ebfee83..b4f30aeb1 100644 --- a/client/src/test/groovy/com/netflix/conductor/client/http/WorkflowClientSpec.groovy +++ b/client/src/test/groovy/com/netflix/conductor/client/http/WorkflowClientSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/test/java/com/netflix/conductor/client/automator/PollingSemaphoreTest.java b/client/src/test/java/com/netflix/conductor/client/automator/PollingSemaphoreTest.java index 38735b120..7bc7e7c3a 100644 --- a/client/src/test/java/com/netflix/conductor/client/automator/PollingSemaphoreTest.java +++ b/client/src/test/java/com/netflix/conductor/client/automator/PollingSemaphoreTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/test/java/com/netflix/conductor/client/automator/TaskPollExecutorTest.java b/client/src/test/java/com/netflix/conductor/client/automator/TaskPollExecutorTest.java index 5bbe8ba24..60855bdae 100644 --- a/client/src/test/java/com/netflix/conductor/client/automator/TaskPollExecutorTest.java +++ b/client/src/test/java/com/netflix/conductor/client/automator/TaskPollExecutorTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/test/java/com/netflix/conductor/client/automator/TaskRunnerConfigurerTest.java b/client/src/test/java/com/netflix/conductor/client/automator/TaskRunnerConfigurerTest.java index d86ae76f1..cbd9df8a9 100644 --- a/client/src/test/java/com/netflix/conductor/client/automator/TaskRunnerConfigurerTest.java +++ b/client/src/test/java/com/netflix/conductor/client/automator/TaskRunnerConfigurerTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/test/java/com/netflix/conductor/client/config/TestPropertyFactory.java b/client/src/test/java/com/netflix/conductor/client/config/TestPropertyFactory.java index 87b6f40e4..398738c59 100644 --- a/client/src/test/java/com/netflix/conductor/client/config/TestPropertyFactory.java +++ b/client/src/test/java/com/netflix/conductor/client/config/TestPropertyFactory.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/test/java/com/netflix/conductor/client/sample/Main.java b/client/src/test/java/com/netflix/conductor/client/sample/Main.java index 6fbbb00d1..7a474b146 100644 --- a/client/src/test/java/com/netflix/conductor/client/sample/Main.java +++ b/client/src/test/java/com/netflix/conductor/client/sample/Main.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/test/java/com/netflix/conductor/client/sample/SampleWorker.java b/client/src/test/java/com/netflix/conductor/client/sample/SampleWorker.java index cc2cbda60..6073c3f90 100644 --- a/client/src/test/java/com/netflix/conductor/client/sample/SampleWorker.java +++ b/client/src/test/java/com/netflix/conductor/client/sample/SampleWorker.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/test/java/com/netflix/conductor/client/testing/AbstractWorkflowTests.java b/client/src/test/java/com/netflix/conductor/client/testing/AbstractWorkflowTests.java index 69703816d..c2afa03f3 100644 --- a/client/src/test/java/com/netflix/conductor/client/testing/AbstractWorkflowTests.java +++ b/client/src/test/java/com/netflix/conductor/client/testing/AbstractWorkflowTests.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/test/java/com/netflix/conductor/client/testing/LoanWorkflowInput.java b/client/src/test/java/com/netflix/conductor/client/testing/LoanWorkflowInput.java index cb48576a6..cd73b1af4 100644 --- a/client/src/test/java/com/netflix/conductor/client/testing/LoanWorkflowInput.java +++ b/client/src/test/java/com/netflix/conductor/client/testing/LoanWorkflowInput.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/test/java/com/netflix/conductor/client/testing/LoanWorkflowTest.java b/client/src/test/java/com/netflix/conductor/client/testing/LoanWorkflowTest.java index df09964d8..84f876a1a 100644 --- a/client/src/test/java/com/netflix/conductor/client/testing/LoanWorkflowTest.java +++ b/client/src/test/java/com/netflix/conductor/client/testing/LoanWorkflowTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/test/java/com/netflix/conductor/client/testing/RegressionTest.java b/client/src/test/java/com/netflix/conductor/client/testing/RegressionTest.java index 4b51a2df2..e67f83658 100644 --- a/client/src/test/java/com/netflix/conductor/client/testing/RegressionTest.java +++ b/client/src/test/java/com/netflix/conductor/client/testing/RegressionTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/test/java/com/netflix/conductor/client/testing/SubWorkflowTest.java b/client/src/test/java/com/netflix/conductor/client/testing/SubWorkflowTest.java index 5994d8c1c..f01d3f921 100644 --- a/client/src/test/java/com/netflix/conductor/client/testing/SubWorkflowTest.java +++ b/client/src/test/java/com/netflix/conductor/client/testing/SubWorkflowTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/client/src/test/java/com/netflix/conductor/client/worker/TestWorkflowTask.java b/client/src/test/java/com/netflix/conductor/client/worker/TestWorkflowTask.java index 62720e92f..32f7bcb76 100644 --- a/client/src/test/java/com/netflix/conductor/client/worker/TestWorkflowTask.java +++ b/client/src/test/java/com/netflix/conductor/client/worker/TestWorkflowTask.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common-persistence/src/test/java/com/netflix/conductor/dao/ExecutionDAOTest.java b/common-persistence/src/test/java/com/netflix/conductor/dao/ExecutionDAOTest.java index a2688688d..fc4068706 100644 --- a/common-persistence/src/test/java/com/netflix/conductor/dao/ExecutionDAOTest.java +++ b/common-persistence/src/test/java/com/netflix/conductor/dao/ExecutionDAOTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common-persistence/src/test/java/com/netflix/conductor/dao/TestBase.java b/common-persistence/src/test/java/com/netflix/conductor/dao/TestBase.java index eb78c531b..7d1d14106 100644 --- a/common-persistence/src/test/java/com/netflix/conductor/dao/TestBase.java +++ b/common-persistence/src/test/java/com/netflix/conductor/dao/TestBase.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/config/ObjectMapperBuilderConfiguration.java b/common/src/main/java/com/netflix/conductor/common/config/ObjectMapperBuilderConfiguration.java index a281edb34..40b781eab 100644 --- a/common/src/main/java/com/netflix/conductor/common/config/ObjectMapperBuilderConfiguration.java +++ b/common/src/main/java/com/netflix/conductor/common/config/ObjectMapperBuilderConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/config/ObjectMapperConfiguration.java b/common/src/main/java/com/netflix/conductor/common/config/ObjectMapperConfiguration.java index fefce75ba..9d698cb1b 100644 --- a/common/src/main/java/com/netflix/conductor/common/config/ObjectMapperConfiguration.java +++ b/common/src/main/java/com/netflix/conductor/common/config/ObjectMapperConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/config/ObjectMapperProvider.java b/common/src/main/java/com/netflix/conductor/common/config/ObjectMapperProvider.java index 43398df79..51ebfc8cf 100644 --- a/common/src/main/java/com/netflix/conductor/common/config/ObjectMapperProvider.java +++ b/common/src/main/java/com/netflix/conductor/common/config/ObjectMapperProvider.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/constraints/NoSemiColonConstraint.java b/common/src/main/java/com/netflix/conductor/common/constraints/NoSemiColonConstraint.java index 6f3015e6a..b3482c979 100644 --- a/common/src/main/java/com/netflix/conductor/common/constraints/NoSemiColonConstraint.java +++ b/common/src/main/java/com/netflix/conductor/common/constraints/NoSemiColonConstraint.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/constraints/OwnerEmailMandatoryConstraint.java b/common/src/main/java/com/netflix/conductor/common/constraints/OwnerEmailMandatoryConstraint.java index b010b4bb3..297d61442 100644 --- a/common/src/main/java/com/netflix/conductor/common/constraints/OwnerEmailMandatoryConstraint.java +++ b/common/src/main/java/com/netflix/conductor/common/constraints/OwnerEmailMandatoryConstraint.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/constraints/TaskReferenceNameUniqueConstraint.java b/common/src/main/java/com/netflix/conductor/common/constraints/TaskReferenceNameUniqueConstraint.java index f9dbc4c79..3d325f577 100644 --- a/common/src/main/java/com/netflix/conductor/common/constraints/TaskReferenceNameUniqueConstraint.java +++ b/common/src/main/java/com/netflix/conductor/common/constraints/TaskReferenceNameUniqueConstraint.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/constraints/TaskTimeoutConstraint.java b/common/src/main/java/com/netflix/conductor/common/constraints/TaskTimeoutConstraint.java index a498dca65..a9e6576f0 100644 --- a/common/src/main/java/com/netflix/conductor/common/constraints/TaskTimeoutConstraint.java +++ b/common/src/main/java/com/netflix/conductor/common/constraints/TaskTimeoutConstraint.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/jackson/JsonProtoModule.java b/common/src/main/java/com/netflix/conductor/common/jackson/JsonProtoModule.java index 29bb5e11d..b109e8ea9 100644 --- a/common/src/main/java/com/netflix/conductor/common/jackson/JsonProtoModule.java +++ b/common/src/main/java/com/netflix/conductor/common/jackson/JsonProtoModule.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/metadata/Auditable.java b/common/src/main/java/com/netflix/conductor/common/metadata/Auditable.java index 01f229480..fcdfdf9fa 100644 --- a/common/src/main/java/com/netflix/conductor/common/metadata/Auditable.java +++ b/common/src/main/java/com/netflix/conductor/common/metadata/Auditable.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/metadata/BaseDef.java b/common/src/main/java/com/netflix/conductor/common/metadata/BaseDef.java index d638d2d32..7fec07255 100644 --- a/common/src/main/java/com/netflix/conductor/common/metadata/BaseDef.java +++ b/common/src/main/java/com/netflix/conductor/common/metadata/BaseDef.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/metadata/acl/Permission.java b/common/src/main/java/com/netflix/conductor/common/metadata/acl/Permission.java index 26736f77e..dfcc77571 100644 --- a/common/src/main/java/com/netflix/conductor/common/metadata/acl/Permission.java +++ b/common/src/main/java/com/netflix/conductor/common/metadata/acl/Permission.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/metadata/events/EventExecution.java b/common/src/main/java/com/netflix/conductor/common/metadata/events/EventExecution.java index d6a2065e6..fd5310ac5 100644 --- a/common/src/main/java/com/netflix/conductor/common/metadata/events/EventExecution.java +++ b/common/src/main/java/com/netflix/conductor/common/metadata/events/EventExecution.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/metadata/events/EventHandler.java b/common/src/main/java/com/netflix/conductor/common/metadata/events/EventHandler.java index 24084f2de..0321c85b7 100644 --- a/common/src/main/java/com/netflix/conductor/common/metadata/events/EventHandler.java +++ b/common/src/main/java/com/netflix/conductor/common/metadata/events/EventHandler.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/metadata/tasks/PollData.java b/common/src/main/java/com/netflix/conductor/common/metadata/tasks/PollData.java index b058e2cd4..f094fb20a 100644 --- a/common/src/main/java/com/netflix/conductor/common/metadata/tasks/PollData.java +++ b/common/src/main/java/com/netflix/conductor/common/metadata/tasks/PollData.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/metadata/tasks/Task.java b/common/src/main/java/com/netflix/conductor/common/metadata/tasks/Task.java index f51016340..90fd0ee4a 100644 --- a/common/src/main/java/com/netflix/conductor/common/metadata/tasks/Task.java +++ b/common/src/main/java/com/netflix/conductor/common/metadata/tasks/Task.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/metadata/tasks/TaskDef.java b/common/src/main/java/com/netflix/conductor/common/metadata/tasks/TaskDef.java index 658079e0a..f6d5964d7 100644 --- a/common/src/main/java/com/netflix/conductor/common/metadata/tasks/TaskDef.java +++ b/common/src/main/java/com/netflix/conductor/common/metadata/tasks/TaskDef.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/metadata/tasks/TaskExecLog.java b/common/src/main/java/com/netflix/conductor/common/metadata/tasks/TaskExecLog.java index 256e1da6f..a04eb1257 100644 --- a/common/src/main/java/com/netflix/conductor/common/metadata/tasks/TaskExecLog.java +++ b/common/src/main/java/com/netflix/conductor/common/metadata/tasks/TaskExecLog.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/metadata/tasks/TaskResult.java b/common/src/main/java/com/netflix/conductor/common/metadata/tasks/TaskResult.java index f31b6481b..704c9fa70 100644 --- a/common/src/main/java/com/netflix/conductor/common/metadata/tasks/TaskResult.java +++ b/common/src/main/java/com/netflix/conductor/common/metadata/tasks/TaskResult.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/metadata/tasks/TaskType.java b/common/src/main/java/com/netflix/conductor/common/metadata/tasks/TaskType.java index 235a0ac91..902027b02 100644 --- a/common/src/main/java/com/netflix/conductor/common/metadata/tasks/TaskType.java +++ b/common/src/main/java/com/netflix/conductor/common/metadata/tasks/TaskType.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/metadata/workflow/DynamicForkJoinTask.java b/common/src/main/java/com/netflix/conductor/common/metadata/workflow/DynamicForkJoinTask.java index d95354ef5..05c5dfbfb 100644 --- a/common/src/main/java/com/netflix/conductor/common/metadata/workflow/DynamicForkJoinTask.java +++ b/common/src/main/java/com/netflix/conductor/common/metadata/workflow/DynamicForkJoinTask.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/metadata/workflow/DynamicForkJoinTaskList.java b/common/src/main/java/com/netflix/conductor/common/metadata/workflow/DynamicForkJoinTaskList.java index f11530dc7..ca5292b51 100644 --- a/common/src/main/java/com/netflix/conductor/common/metadata/workflow/DynamicForkJoinTaskList.java +++ b/common/src/main/java/com/netflix/conductor/common/metadata/workflow/DynamicForkJoinTaskList.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/metadata/workflow/RerunWorkflowRequest.java b/common/src/main/java/com/netflix/conductor/common/metadata/workflow/RerunWorkflowRequest.java index 67c1b86a7..82d802109 100644 --- a/common/src/main/java/com/netflix/conductor/common/metadata/workflow/RerunWorkflowRequest.java +++ b/common/src/main/java/com/netflix/conductor/common/metadata/workflow/RerunWorkflowRequest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/metadata/workflow/SkipTaskRequest.java b/common/src/main/java/com/netflix/conductor/common/metadata/workflow/SkipTaskRequest.java index 8540794a6..42371c943 100644 --- a/common/src/main/java/com/netflix/conductor/common/metadata/workflow/SkipTaskRequest.java +++ b/common/src/main/java/com/netflix/conductor/common/metadata/workflow/SkipTaskRequest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/metadata/workflow/StartWorkflowRequest.java b/common/src/main/java/com/netflix/conductor/common/metadata/workflow/StartWorkflowRequest.java index e44edca62..fc8f83af7 100644 --- a/common/src/main/java/com/netflix/conductor/common/metadata/workflow/StartWorkflowRequest.java +++ b/common/src/main/java/com/netflix/conductor/common/metadata/workflow/StartWorkflowRequest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/metadata/workflow/SubWorkflowParams.java b/common/src/main/java/com/netflix/conductor/common/metadata/workflow/SubWorkflowParams.java index 9cb934b64..d2fbb6f3b 100644 --- a/common/src/main/java/com/netflix/conductor/common/metadata/workflow/SubWorkflowParams.java +++ b/common/src/main/java/com/netflix/conductor/common/metadata/workflow/SubWorkflowParams.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/metadata/workflow/WorkflowDef.java b/common/src/main/java/com/netflix/conductor/common/metadata/workflow/WorkflowDef.java index 6d0676026..02c4d0149 100644 --- a/common/src/main/java/com/netflix/conductor/common/metadata/workflow/WorkflowDef.java +++ b/common/src/main/java/com/netflix/conductor/common/metadata/workflow/WorkflowDef.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/metadata/workflow/WorkflowDefSummary.java b/common/src/main/java/com/netflix/conductor/common/metadata/workflow/WorkflowDefSummary.java index bf22c0265..6c8d1f36e 100644 --- a/common/src/main/java/com/netflix/conductor/common/metadata/workflow/WorkflowDefSummary.java +++ b/common/src/main/java/com/netflix/conductor/common/metadata/workflow/WorkflowDefSummary.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/metadata/workflow/WorkflowTask.java b/common/src/main/java/com/netflix/conductor/common/metadata/workflow/WorkflowTask.java index 6395596f8..94c9c00e0 100644 --- a/common/src/main/java/com/netflix/conductor/common/metadata/workflow/WorkflowTask.java +++ b/common/src/main/java/com/netflix/conductor/common/metadata/workflow/WorkflowTask.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/model/BulkResponse.java b/common/src/main/java/com/netflix/conductor/common/model/BulkResponse.java index b0f5b38e6..b4133b5bf 100644 --- a/common/src/main/java/com/netflix/conductor/common/model/BulkResponse.java +++ b/common/src/main/java/com/netflix/conductor/common/model/BulkResponse.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/run/ExternalStorageLocation.java b/common/src/main/java/com/netflix/conductor/common/run/ExternalStorageLocation.java index 5c3071613..d94b35837 100644 --- a/common/src/main/java/com/netflix/conductor/common/run/ExternalStorageLocation.java +++ b/common/src/main/java/com/netflix/conductor/common/run/ExternalStorageLocation.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/run/SearchResult.java b/common/src/main/java/com/netflix/conductor/common/run/SearchResult.java index 72be415a9..43057d985 100644 --- a/common/src/main/java/com/netflix/conductor/common/run/SearchResult.java +++ b/common/src/main/java/com/netflix/conductor/common/run/SearchResult.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/run/TaskSummary.java b/common/src/main/java/com/netflix/conductor/common/run/TaskSummary.java index b9e0baa6c..32e3b0f71 100644 --- a/common/src/main/java/com/netflix/conductor/common/run/TaskSummary.java +++ b/common/src/main/java/com/netflix/conductor/common/run/TaskSummary.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/run/Workflow.java b/common/src/main/java/com/netflix/conductor/common/run/Workflow.java index b84c99775..26a8b5598 100644 --- a/common/src/main/java/com/netflix/conductor/common/run/Workflow.java +++ b/common/src/main/java/com/netflix/conductor/common/run/Workflow.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/run/WorkflowSummary.java b/common/src/main/java/com/netflix/conductor/common/run/WorkflowSummary.java index 7fec015fc..9be8d7df1 100644 --- a/common/src/main/java/com/netflix/conductor/common/run/WorkflowSummary.java +++ b/common/src/main/java/com/netflix/conductor/common/run/WorkflowSummary.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/run/WorkflowTestRequest.java b/common/src/main/java/com/netflix/conductor/common/run/WorkflowTestRequest.java index e5007348b..e41394688 100644 --- a/common/src/main/java/com/netflix/conductor/common/run/WorkflowTestRequest.java +++ b/common/src/main/java/com/netflix/conductor/common/run/WorkflowTestRequest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/utils/ConstraintParamUtil.java b/common/src/main/java/com/netflix/conductor/common/utils/ConstraintParamUtil.java index 3f2eea503..249db9dcd 100644 --- a/common/src/main/java/com/netflix/conductor/common/utils/ConstraintParamUtil.java +++ b/common/src/main/java/com/netflix/conductor/common/utils/ConstraintParamUtil.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/utils/EnvUtils.java b/common/src/main/java/com/netflix/conductor/common/utils/EnvUtils.java index 202f1f31c..7cb8ab463 100644 --- a/common/src/main/java/com/netflix/conductor/common/utils/EnvUtils.java +++ b/common/src/main/java/com/netflix/conductor/common/utils/EnvUtils.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/utils/ExternalPayloadStorage.java b/common/src/main/java/com/netflix/conductor/common/utils/ExternalPayloadStorage.java index abe74c734..f246b84b7 100644 --- a/common/src/main/java/com/netflix/conductor/common/utils/ExternalPayloadStorage.java +++ b/common/src/main/java/com/netflix/conductor/common/utils/ExternalPayloadStorage.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/utils/SummaryUtil.java b/common/src/main/java/com/netflix/conductor/common/utils/SummaryUtil.java index 60502402f..85c0e2010 100644 --- a/common/src/main/java/com/netflix/conductor/common/utils/SummaryUtil.java +++ b/common/src/main/java/com/netflix/conductor/common/utils/SummaryUtil.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/utils/TaskUtils.java b/common/src/main/java/com/netflix/conductor/common/utils/TaskUtils.java index 5e83bd73e..6ba1f11ba 100644 --- a/common/src/main/java/com/netflix/conductor/common/utils/TaskUtils.java +++ b/common/src/main/java/com/netflix/conductor/common/utils/TaskUtils.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/validation/ErrorResponse.java b/common/src/main/java/com/netflix/conductor/common/validation/ErrorResponse.java index 5ed6256e1..f9183c928 100644 --- a/common/src/main/java/com/netflix/conductor/common/validation/ErrorResponse.java +++ b/common/src/main/java/com/netflix/conductor/common/validation/ErrorResponse.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/main/java/com/netflix/conductor/common/validation/ValidationError.java b/common/src/main/java/com/netflix/conductor/common/validation/ValidationError.java index 48a53e066..82d63f520 100644 --- a/common/src/main/java/com/netflix/conductor/common/validation/ValidationError.java +++ b/common/src/main/java/com/netflix/conductor/common/validation/ValidationError.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/test/java/com/netflix/conductor/common/config/TestObjectMapperConfiguration.java b/common/src/test/java/com/netflix/conductor/common/config/TestObjectMapperConfiguration.java index 014a118dd..b835693f9 100644 --- a/common/src/test/java/com/netflix/conductor/common/config/TestObjectMapperConfiguration.java +++ b/common/src/test/java/com/netflix/conductor/common/config/TestObjectMapperConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/test/java/com/netflix/conductor/common/events/EventHandlerTest.java b/common/src/test/java/com/netflix/conductor/common/events/EventHandlerTest.java index 36cf22c50..db23c69dd 100644 --- a/common/src/test/java/com/netflix/conductor/common/events/EventHandlerTest.java +++ b/common/src/test/java/com/netflix/conductor/common/events/EventHandlerTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/test/java/com/netflix/conductor/common/run/TaskSummaryTest.java b/common/src/test/java/com/netflix/conductor/common/run/TaskSummaryTest.java index 4c8ec4e6c..09c7077c1 100644 --- a/common/src/test/java/com/netflix/conductor/common/run/TaskSummaryTest.java +++ b/common/src/test/java/com/netflix/conductor/common/run/TaskSummaryTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/test/java/com/netflix/conductor/common/tasks/TaskDefTest.java b/common/src/test/java/com/netflix/conductor/common/tasks/TaskDefTest.java index 7e5108b05..f370138fc 100644 --- a/common/src/test/java/com/netflix/conductor/common/tasks/TaskDefTest.java +++ b/common/src/test/java/com/netflix/conductor/common/tasks/TaskDefTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/test/java/com/netflix/conductor/common/tasks/TaskResultTest.java b/common/src/test/java/com/netflix/conductor/common/tasks/TaskResultTest.java index a49fa2daf..54888202d 100644 --- a/common/src/test/java/com/netflix/conductor/common/tasks/TaskResultTest.java +++ b/common/src/test/java/com/netflix/conductor/common/tasks/TaskResultTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/test/java/com/netflix/conductor/common/tasks/TaskTest.java b/common/src/test/java/com/netflix/conductor/common/tasks/TaskTest.java index e392f65b5..255108170 100644 --- a/common/src/test/java/com/netflix/conductor/common/tasks/TaskTest.java +++ b/common/src/test/java/com/netflix/conductor/common/tasks/TaskTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/test/java/com/netflix/conductor/common/utils/ConstraintParamUtilTest.java b/common/src/test/java/com/netflix/conductor/common/utils/ConstraintParamUtilTest.java index d29f1744e..543035054 100644 --- a/common/src/test/java/com/netflix/conductor/common/utils/ConstraintParamUtilTest.java +++ b/common/src/test/java/com/netflix/conductor/common/utils/ConstraintParamUtilTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/test/java/com/netflix/conductor/common/utils/SummaryUtilTest.java b/common/src/test/java/com/netflix/conductor/common/utils/SummaryUtilTest.java index 79fae89d9..435434f28 100644 --- a/common/src/test/java/com/netflix/conductor/common/utils/SummaryUtilTest.java +++ b/common/src/test/java/com/netflix/conductor/common/utils/SummaryUtilTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/test/java/com/netflix/conductor/common/workflow/SubWorkflowParamsTest.java b/common/src/test/java/com/netflix/conductor/common/workflow/SubWorkflowParamsTest.java index bda8e0ddb..d32afc5f6 100644 --- a/common/src/test/java/com/netflix/conductor/common/workflow/SubWorkflowParamsTest.java +++ b/common/src/test/java/com/netflix/conductor/common/workflow/SubWorkflowParamsTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/test/java/com/netflix/conductor/common/workflow/WorkflowDefValidatorTest.java b/common/src/test/java/com/netflix/conductor/common/workflow/WorkflowDefValidatorTest.java index 2ed545418..d08acdc77 100644 --- a/common/src/test/java/com/netflix/conductor/common/workflow/WorkflowDefValidatorTest.java +++ b/common/src/test/java/com/netflix/conductor/common/workflow/WorkflowDefValidatorTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/common/src/test/java/com/netflix/conductor/common/workflow/WorkflowTaskTest.java b/common/src/test/java/com/netflix/conductor/common/workflow/WorkflowTaskTest.java index 0d9ea921e..12a8aa399 100644 --- a/common/src/test/java/com/netflix/conductor/common/workflow/WorkflowTaskTest.java +++ b/common/src/test/java/com/netflix/conductor/common/workflow/WorkflowTaskTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/annotations/Audit.java b/core/src/main/java/com/netflix/conductor/annotations/Audit.java index 6f1d47199..3e55d7804 100644 --- a/core/src/main/java/com/netflix/conductor/annotations/Audit.java +++ b/core/src/main/java/com/netflix/conductor/annotations/Audit.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/annotations/Trace.java b/core/src/main/java/com/netflix/conductor/annotations/Trace.java index 61da42cc4..cf2b9ec5e 100644 --- a/core/src/main/java/com/netflix/conductor/annotations/Trace.java +++ b/core/src/main/java/com/netflix/conductor/annotations/Trace.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/annotations/VisibleForTesting.java b/core/src/main/java/com/netflix/conductor/annotations/VisibleForTesting.java index 492931128..fb1ae76b6 100644 --- a/core/src/main/java/com/netflix/conductor/annotations/VisibleForTesting.java +++ b/core/src/main/java/com/netflix/conductor/annotations/VisibleForTesting.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/LifecycleAwareComponent.java b/core/src/main/java/com/netflix/conductor/core/LifecycleAwareComponent.java index bfe1455fb..153cea1fb 100644 --- a/core/src/main/java/com/netflix/conductor/core/LifecycleAwareComponent.java +++ b/core/src/main/java/com/netflix/conductor/core/LifecycleAwareComponent.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/WorkflowContext.java b/core/src/main/java/com/netflix/conductor/core/WorkflowContext.java index d870761c5..559506dad 100644 --- a/core/src/main/java/com/netflix/conductor/core/WorkflowContext.java +++ b/core/src/main/java/com/netflix/conductor/core/WorkflowContext.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/config/ConductorCoreConfiguration.java b/core/src/main/java/com/netflix/conductor/core/config/ConductorCoreConfiguration.java index a09403d5f..c0e8de9ee 100644 --- a/core/src/main/java/com/netflix/conductor/core/config/ConductorCoreConfiguration.java +++ b/core/src/main/java/com/netflix/conductor/core/config/ConductorCoreConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/config/ConductorProperties.java b/core/src/main/java/com/netflix/conductor/core/config/ConductorProperties.java index c54b7a9de..80b127372 100644 --- a/core/src/main/java/com/netflix/conductor/core/config/ConductorProperties.java +++ b/core/src/main/java/com/netflix/conductor/core/config/ConductorProperties.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/config/SchedulerConfiguration.java b/core/src/main/java/com/netflix/conductor/core/config/SchedulerConfiguration.java index 364406e10..b63366649 100644 --- a/core/src/main/java/com/netflix/conductor/core/config/SchedulerConfiguration.java +++ b/core/src/main/java/com/netflix/conductor/core/config/SchedulerConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/dal/ExecutionDAOFacade.java b/core/src/main/java/com/netflix/conductor/core/dal/ExecutionDAOFacade.java index 92255bc4d..c5cdff08c 100644 --- a/core/src/main/java/com/netflix/conductor/core/dal/ExecutionDAOFacade.java +++ b/core/src/main/java/com/netflix/conductor/core/dal/ExecutionDAOFacade.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/event/WorkflowCreationEvent.java b/core/src/main/java/com/netflix/conductor/core/event/WorkflowCreationEvent.java index 28c4fca72..c6d7085ef 100644 --- a/core/src/main/java/com/netflix/conductor/core/event/WorkflowCreationEvent.java +++ b/core/src/main/java/com/netflix/conductor/core/event/WorkflowCreationEvent.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/event/WorkflowEvaluationEvent.java b/core/src/main/java/com/netflix/conductor/core/event/WorkflowEvaluationEvent.java index 2b139636c..267224b56 100644 --- a/core/src/main/java/com/netflix/conductor/core/event/WorkflowEvaluationEvent.java +++ b/core/src/main/java/com/netflix/conductor/core/event/WorkflowEvaluationEvent.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/events/ActionProcessor.java b/core/src/main/java/com/netflix/conductor/core/events/ActionProcessor.java index 6b8139652..83e60fbb8 100644 --- a/core/src/main/java/com/netflix/conductor/core/events/ActionProcessor.java +++ b/core/src/main/java/com/netflix/conductor/core/events/ActionProcessor.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/events/DefaultEventProcessor.java b/core/src/main/java/com/netflix/conductor/core/events/DefaultEventProcessor.java index fa7f1725b..dbdbf6b15 100644 --- a/core/src/main/java/com/netflix/conductor/core/events/DefaultEventProcessor.java +++ b/core/src/main/java/com/netflix/conductor/core/events/DefaultEventProcessor.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/events/DefaultEventQueueManager.java b/core/src/main/java/com/netflix/conductor/core/events/DefaultEventQueueManager.java index 862287cac..a83755069 100644 --- a/core/src/main/java/com/netflix/conductor/core/events/DefaultEventQueueManager.java +++ b/core/src/main/java/com/netflix/conductor/core/events/DefaultEventQueueManager.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/events/EventQueueManager.java b/core/src/main/java/com/netflix/conductor/core/events/EventQueueManager.java index fc6a568f6..7580af79c 100644 --- a/core/src/main/java/com/netflix/conductor/core/events/EventQueueManager.java +++ b/core/src/main/java/com/netflix/conductor/core/events/EventQueueManager.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/events/EventQueueProvider.java b/core/src/main/java/com/netflix/conductor/core/events/EventQueueProvider.java index 8bd11f929..22e3cecc3 100644 --- a/core/src/main/java/com/netflix/conductor/core/events/EventQueueProvider.java +++ b/core/src/main/java/com/netflix/conductor/core/events/EventQueueProvider.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/events/EventQueues.java b/core/src/main/java/com/netflix/conductor/core/events/EventQueues.java index b4ab2e388..9cbe08a46 100644 --- a/core/src/main/java/com/netflix/conductor/core/events/EventQueues.java +++ b/core/src/main/java/com/netflix/conductor/core/events/EventQueues.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/events/ScriptEvaluator.java b/core/src/main/java/com/netflix/conductor/core/events/ScriptEvaluator.java index dc46354b0..1cd5e4a89 100644 --- a/core/src/main/java/com/netflix/conductor/core/events/ScriptEvaluator.java +++ b/core/src/main/java/com/netflix/conductor/core/events/ScriptEvaluator.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/events/SimpleActionProcessor.java b/core/src/main/java/com/netflix/conductor/core/events/SimpleActionProcessor.java index 27b81edf7..a91bcad43 100644 --- a/core/src/main/java/com/netflix/conductor/core/events/SimpleActionProcessor.java +++ b/core/src/main/java/com/netflix/conductor/core/events/SimpleActionProcessor.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/events/queue/ConductorEventQueueProvider.java b/core/src/main/java/com/netflix/conductor/core/events/queue/ConductorEventQueueProvider.java index 76e530101..478a8d7b2 100644 --- a/core/src/main/java/com/netflix/conductor/core/events/queue/ConductorEventQueueProvider.java +++ b/core/src/main/java/com/netflix/conductor/core/events/queue/ConductorEventQueueProvider.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/events/queue/ConductorObservableQueue.java b/core/src/main/java/com/netflix/conductor/core/events/queue/ConductorObservableQueue.java index 649cc7b50..e4689423d 100644 --- a/core/src/main/java/com/netflix/conductor/core/events/queue/ConductorObservableQueue.java +++ b/core/src/main/java/com/netflix/conductor/core/events/queue/ConductorObservableQueue.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/events/queue/DefaultEventQueueProcessor.java b/core/src/main/java/com/netflix/conductor/core/events/queue/DefaultEventQueueProcessor.java index f1c508803..ff49a173f 100644 --- a/core/src/main/java/com/netflix/conductor/core/events/queue/DefaultEventQueueProcessor.java +++ b/core/src/main/java/com/netflix/conductor/core/events/queue/DefaultEventQueueProcessor.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/events/queue/Message.java b/core/src/main/java/com/netflix/conductor/core/events/queue/Message.java index b7d33961f..edefe53af 100644 --- a/core/src/main/java/com/netflix/conductor/core/events/queue/Message.java +++ b/core/src/main/java/com/netflix/conductor/core/events/queue/Message.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/events/queue/ObservableQueue.java b/core/src/main/java/com/netflix/conductor/core/events/queue/ObservableQueue.java index ecdc75921..ac5098ea7 100644 --- a/core/src/main/java/com/netflix/conductor/core/events/queue/ObservableQueue.java +++ b/core/src/main/java/com/netflix/conductor/core/events/queue/ObservableQueue.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/exception/ConflictException.java b/core/src/main/java/com/netflix/conductor/core/exception/ConflictException.java index 7c718ed59..21cbd6071 100644 --- a/core/src/main/java/com/netflix/conductor/core/exception/ConflictException.java +++ b/core/src/main/java/com/netflix/conductor/core/exception/ConflictException.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/exception/NonTransientException.java b/core/src/main/java/com/netflix/conductor/core/exception/NonTransientException.java index 4af05633f..0bf93d14d 100644 --- a/core/src/main/java/com/netflix/conductor/core/exception/NonTransientException.java +++ b/core/src/main/java/com/netflix/conductor/core/exception/NonTransientException.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/exception/NotFoundException.java b/core/src/main/java/com/netflix/conductor/core/exception/NotFoundException.java index a89b7beed..03f4d1d5c 100644 --- a/core/src/main/java/com/netflix/conductor/core/exception/NotFoundException.java +++ b/core/src/main/java/com/netflix/conductor/core/exception/NotFoundException.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/exception/TerminateWorkflowException.java b/core/src/main/java/com/netflix/conductor/core/exception/TerminateWorkflowException.java index 366c4864f..aa8ec4a50 100644 --- a/core/src/main/java/com/netflix/conductor/core/exception/TerminateWorkflowException.java +++ b/core/src/main/java/com/netflix/conductor/core/exception/TerminateWorkflowException.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/exception/TransientException.java b/core/src/main/java/com/netflix/conductor/core/exception/TransientException.java index 87cc9d852..c6e536b15 100644 --- a/core/src/main/java/com/netflix/conductor/core/exception/TransientException.java +++ b/core/src/main/java/com/netflix/conductor/core/exception/TransientException.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/AsyncSystemTaskExecutor.java b/core/src/main/java/com/netflix/conductor/core/execution/AsyncSystemTaskExecutor.java index 331a2b4ac..8751f1582 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/AsyncSystemTaskExecutor.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/AsyncSystemTaskExecutor.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/DeciderService.java b/core/src/main/java/com/netflix/conductor/core/execution/DeciderService.java index c6bf486ba..6d7a42e70 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/DeciderService.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/DeciderService.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/StartWorkflowInput.java b/core/src/main/java/com/netflix/conductor/core/execution/StartWorkflowInput.java index 7eb8fb93d..f24ea2771 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/StartWorkflowInput.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/StartWorkflowInput.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/WorkflowExecutor.java b/core/src/main/java/com/netflix/conductor/core/execution/WorkflowExecutor.java index 6070741a2..84ee5e001 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/WorkflowExecutor.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/WorkflowExecutor.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/evaluators/Evaluator.java b/core/src/main/java/com/netflix/conductor/core/execution/evaluators/Evaluator.java index 88d01ef7f..13bce2b24 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/evaluators/Evaluator.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/evaluators/Evaluator.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/evaluators/JavascriptEvaluator.java b/core/src/main/java/com/netflix/conductor/core/execution/evaluators/JavascriptEvaluator.java index 8f2de942d..4a22bdbe9 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/evaluators/JavascriptEvaluator.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/evaluators/JavascriptEvaluator.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/evaluators/ValueParamEvaluator.java b/core/src/main/java/com/netflix/conductor/core/execution/evaluators/ValueParamEvaluator.java index f1fda6178..94c34b0d0 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/evaluators/ValueParamEvaluator.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/evaluators/ValueParamEvaluator.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/mapper/DecisionTaskMapper.java b/core/src/main/java/com/netflix/conductor/core/execution/mapper/DecisionTaskMapper.java index d3f494f3b..4ac394de8 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/mapper/DecisionTaskMapper.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/mapper/DecisionTaskMapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/mapper/DoWhileTaskMapper.java b/core/src/main/java/com/netflix/conductor/core/execution/mapper/DoWhileTaskMapper.java index 66e6978d7..85ff93e81 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/mapper/DoWhileTaskMapper.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/mapper/DoWhileTaskMapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/mapper/DynamicTaskMapper.java b/core/src/main/java/com/netflix/conductor/core/execution/mapper/DynamicTaskMapper.java index a669cc33c..d94af8f0b 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/mapper/DynamicTaskMapper.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/mapper/DynamicTaskMapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/mapper/EventTaskMapper.java b/core/src/main/java/com/netflix/conductor/core/execution/mapper/EventTaskMapper.java index c65423a59..96b9d582f 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/mapper/EventTaskMapper.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/mapper/EventTaskMapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/mapper/ExclusiveJoinTaskMapper.java b/core/src/main/java/com/netflix/conductor/core/execution/mapper/ExclusiveJoinTaskMapper.java index dc648f015..587460cf9 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/mapper/ExclusiveJoinTaskMapper.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/mapper/ExclusiveJoinTaskMapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/mapper/ForkJoinDynamicTaskMapper.java b/core/src/main/java/com/netflix/conductor/core/execution/mapper/ForkJoinDynamicTaskMapper.java index 8d9126df8..e0acd5b9f 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/mapper/ForkJoinDynamicTaskMapper.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/mapper/ForkJoinDynamicTaskMapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/mapper/ForkJoinTaskMapper.java b/core/src/main/java/com/netflix/conductor/core/execution/mapper/ForkJoinTaskMapper.java index 7ac7f7d3d..aefabb0a1 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/mapper/ForkJoinTaskMapper.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/mapper/ForkJoinTaskMapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/mapper/HTTPTaskMapper.java b/core/src/main/java/com/netflix/conductor/core/execution/mapper/HTTPTaskMapper.java index 123e0aa76..837e49549 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/mapper/HTTPTaskMapper.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/mapper/HTTPTaskMapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/mapper/HumanTaskMapper.java b/core/src/main/java/com/netflix/conductor/core/execution/mapper/HumanTaskMapper.java index 781dac871..4484337f7 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/mapper/HumanTaskMapper.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/mapper/HumanTaskMapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/mapper/InlineTaskMapper.java b/core/src/main/java/com/netflix/conductor/core/execution/mapper/InlineTaskMapper.java index ac95c5d22..87eac7259 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/mapper/InlineTaskMapper.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/mapper/InlineTaskMapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/mapper/JoinTaskMapper.java b/core/src/main/java/com/netflix/conductor/core/execution/mapper/JoinTaskMapper.java index 9e78154c5..6ae3adb1e 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/mapper/JoinTaskMapper.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/mapper/JoinTaskMapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/mapper/JsonJQTransformTaskMapper.java b/core/src/main/java/com/netflix/conductor/core/execution/mapper/JsonJQTransformTaskMapper.java index c4f0eaeb0..21828e3b7 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/mapper/JsonJQTransformTaskMapper.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/mapper/JsonJQTransformTaskMapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/mapper/KafkaPublishTaskMapper.java b/core/src/main/java/com/netflix/conductor/core/execution/mapper/KafkaPublishTaskMapper.java index 280bf71d5..862504666 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/mapper/KafkaPublishTaskMapper.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/mapper/KafkaPublishTaskMapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/mapper/LambdaTaskMapper.java b/core/src/main/java/com/netflix/conductor/core/execution/mapper/LambdaTaskMapper.java index 0f39ae363..37294faa2 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/mapper/LambdaTaskMapper.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/mapper/LambdaTaskMapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/mapper/NoopTaskMapper.java b/core/src/main/java/com/netflix/conductor/core/execution/mapper/NoopTaskMapper.java index a7f904582..17a53dba4 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/mapper/NoopTaskMapper.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/mapper/NoopTaskMapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/mapper/SetVariableTaskMapper.java b/core/src/main/java/com/netflix/conductor/core/execution/mapper/SetVariableTaskMapper.java index 7881fb87f..e12caf47e 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/mapper/SetVariableTaskMapper.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/mapper/SetVariableTaskMapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/mapper/SimpleTaskMapper.java b/core/src/main/java/com/netflix/conductor/core/execution/mapper/SimpleTaskMapper.java index 1dcf9ddb0..0e1368cd1 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/mapper/SimpleTaskMapper.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/mapper/SimpleTaskMapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/mapper/StartWorkflowTaskMapper.java b/core/src/main/java/com/netflix/conductor/core/execution/mapper/StartWorkflowTaskMapper.java index 4d965bc03..5a377750f 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/mapper/StartWorkflowTaskMapper.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/mapper/StartWorkflowTaskMapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/mapper/SubWorkflowTaskMapper.java b/core/src/main/java/com/netflix/conductor/core/execution/mapper/SubWorkflowTaskMapper.java index a90964dac..ab7d9c291 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/mapper/SubWorkflowTaskMapper.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/mapper/SubWorkflowTaskMapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/mapper/SwitchTaskMapper.java b/core/src/main/java/com/netflix/conductor/core/execution/mapper/SwitchTaskMapper.java index 3503dbb29..2401b5c2c 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/mapper/SwitchTaskMapper.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/mapper/SwitchTaskMapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/mapper/TaskMapper.java b/core/src/main/java/com/netflix/conductor/core/execution/mapper/TaskMapper.java index a80a9076e..9f7d83e4c 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/mapper/TaskMapper.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/mapper/TaskMapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/mapper/TaskMapperContext.java b/core/src/main/java/com/netflix/conductor/core/execution/mapper/TaskMapperContext.java index a34c4a0e4..44f996268 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/mapper/TaskMapperContext.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/mapper/TaskMapperContext.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/mapper/TerminateTaskMapper.java b/core/src/main/java/com/netflix/conductor/core/execution/mapper/TerminateTaskMapper.java index 0491df06d..886f20420 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/mapper/TerminateTaskMapper.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/mapper/TerminateTaskMapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/mapper/UserDefinedTaskMapper.java b/core/src/main/java/com/netflix/conductor/core/execution/mapper/UserDefinedTaskMapper.java index b98288577..ba8f314d2 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/mapper/UserDefinedTaskMapper.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/mapper/UserDefinedTaskMapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/mapper/WaitTaskMapper.java b/core/src/main/java/com/netflix/conductor/core/execution/mapper/WaitTaskMapper.java index 6a3ca95d1..fc58d892e 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/mapper/WaitTaskMapper.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/mapper/WaitTaskMapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/tasks/Decision.java b/core/src/main/java/com/netflix/conductor/core/execution/tasks/Decision.java index 0a96845f7..90941edf2 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/tasks/Decision.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/tasks/Decision.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/tasks/DoWhile.java b/core/src/main/java/com/netflix/conductor/core/execution/tasks/DoWhile.java index 3dbc72eb9..f273a8512 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/tasks/DoWhile.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/tasks/DoWhile.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/tasks/Event.java b/core/src/main/java/com/netflix/conductor/core/execution/tasks/Event.java index 8c543ca46..9674efe07 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/tasks/Event.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/tasks/Event.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/tasks/ExclusiveJoin.java b/core/src/main/java/com/netflix/conductor/core/execution/tasks/ExclusiveJoin.java index e2bf0ac0b..fc1325e5e 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/tasks/ExclusiveJoin.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/tasks/ExclusiveJoin.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/tasks/ExecutionConfig.java b/core/src/main/java/com/netflix/conductor/core/execution/tasks/ExecutionConfig.java index 7115dfd1d..0f1a996e7 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/tasks/ExecutionConfig.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/tasks/ExecutionConfig.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/tasks/Fork.java b/core/src/main/java/com/netflix/conductor/core/execution/tasks/Fork.java index 9f31af750..6d7ddf74f 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/tasks/Fork.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/tasks/Fork.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/tasks/Human.java b/core/src/main/java/com/netflix/conductor/core/execution/tasks/Human.java index c4dfc4e31..15528652c 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/tasks/Human.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/tasks/Human.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/tasks/Inline.java b/core/src/main/java/com/netflix/conductor/core/execution/tasks/Inline.java index e53bd7dd4..5641fb441 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/tasks/Inline.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/tasks/Inline.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/tasks/IsolatedTaskQueueProducer.java b/core/src/main/java/com/netflix/conductor/core/execution/tasks/IsolatedTaskQueueProducer.java index 5a5ac33a8..9ac9b4bab 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/tasks/IsolatedTaskQueueProducer.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/tasks/IsolatedTaskQueueProducer.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/tasks/Join.java b/core/src/main/java/com/netflix/conductor/core/execution/tasks/Join.java index e0f7be9fa..a0ad5a96f 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/tasks/Join.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/tasks/Join.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/tasks/Lambda.java b/core/src/main/java/com/netflix/conductor/core/execution/tasks/Lambda.java index d75360e2b..8df79263e 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/tasks/Lambda.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/tasks/Lambda.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/tasks/Noop.java b/core/src/main/java/com/netflix/conductor/core/execution/tasks/Noop.java index 4b9de40a2..49e6083cd 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/tasks/Noop.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/tasks/Noop.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/tasks/SetVariable.java b/core/src/main/java/com/netflix/conductor/core/execution/tasks/SetVariable.java index 2af835cdd..0c8327958 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/tasks/SetVariable.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/tasks/SetVariable.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/tasks/StartWorkflow.java b/core/src/main/java/com/netflix/conductor/core/execution/tasks/StartWorkflow.java index 1096fdf50..b9cb01e0c 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/tasks/StartWorkflow.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/tasks/StartWorkflow.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/tasks/SubWorkflow.java b/core/src/main/java/com/netflix/conductor/core/execution/tasks/SubWorkflow.java index 4b0cc6f04..6e29dd64d 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/tasks/SubWorkflow.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/tasks/SubWorkflow.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/tasks/Switch.java b/core/src/main/java/com/netflix/conductor/core/execution/tasks/Switch.java index 2d3d040a2..bcbd00417 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/tasks/Switch.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/tasks/Switch.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/tasks/SystemTaskRegistry.java b/core/src/main/java/com/netflix/conductor/core/execution/tasks/SystemTaskRegistry.java index 4486680e8..7b9cf743b 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/tasks/SystemTaskRegistry.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/tasks/SystemTaskRegistry.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/tasks/SystemTaskWorker.java b/core/src/main/java/com/netflix/conductor/core/execution/tasks/SystemTaskWorker.java index 9b573f4af..d13334708 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/tasks/SystemTaskWorker.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/tasks/SystemTaskWorker.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/tasks/SystemTaskWorkerCoordinator.java b/core/src/main/java/com/netflix/conductor/core/execution/tasks/SystemTaskWorkerCoordinator.java index b1a9ed988..c192a9639 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/tasks/SystemTaskWorkerCoordinator.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/tasks/SystemTaskWorkerCoordinator.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/tasks/Terminate.java b/core/src/main/java/com/netflix/conductor/core/execution/tasks/Terminate.java index 230ab82c2..23eed4196 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/tasks/Terminate.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/tasks/Terminate.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/tasks/Wait.java b/core/src/main/java/com/netflix/conductor/core/execution/tasks/Wait.java index 903355aa6..2e1a1cc2f 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/tasks/Wait.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/tasks/Wait.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/execution/tasks/WorkflowSystemTask.java b/core/src/main/java/com/netflix/conductor/core/execution/tasks/WorkflowSystemTask.java index b531d0001..9cc17b9e4 100644 --- a/core/src/main/java/com/netflix/conductor/core/execution/tasks/WorkflowSystemTask.java +++ b/core/src/main/java/com/netflix/conductor/core/execution/tasks/WorkflowSystemTask.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/index/NoopIndexDAO.java b/core/src/main/java/com/netflix/conductor/core/index/NoopIndexDAO.java index 5b2d95870..2472c4b38 100644 --- a/core/src/main/java/com/netflix/conductor/core/index/NoopIndexDAO.java +++ b/core/src/main/java/com/netflix/conductor/core/index/NoopIndexDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/index/NoopIndexDAOConfiguration.java b/core/src/main/java/com/netflix/conductor/core/index/NoopIndexDAOConfiguration.java index 0e9e2466b..5de6a6e51 100644 --- a/core/src/main/java/com/netflix/conductor/core/index/NoopIndexDAOConfiguration.java +++ b/core/src/main/java/com/netflix/conductor/core/index/NoopIndexDAOConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/listener/TaskStatusListener.java b/core/src/main/java/com/netflix/conductor/core/listener/TaskStatusListener.java index 2fea7d065..0fc6d61d4 100644 --- a/core/src/main/java/com/netflix/conductor/core/listener/TaskStatusListener.java +++ b/core/src/main/java/com/netflix/conductor/core/listener/TaskStatusListener.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/listener/TaskStatusListenerStub.java b/core/src/main/java/com/netflix/conductor/core/listener/TaskStatusListenerStub.java index 413f5a69e..a53d05243 100644 --- a/core/src/main/java/com/netflix/conductor/core/listener/TaskStatusListenerStub.java +++ b/core/src/main/java/com/netflix/conductor/core/listener/TaskStatusListenerStub.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/listener/WorkflowStatusListener.java b/core/src/main/java/com/netflix/conductor/core/listener/WorkflowStatusListener.java index 1c0c4395a..18dbfeb29 100644 --- a/core/src/main/java/com/netflix/conductor/core/listener/WorkflowStatusListener.java +++ b/core/src/main/java/com/netflix/conductor/core/listener/WorkflowStatusListener.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/listener/WorkflowStatusListenerStub.java b/core/src/main/java/com/netflix/conductor/core/listener/WorkflowStatusListenerStub.java index 36bb5e699..63fe09070 100644 --- a/core/src/main/java/com/netflix/conductor/core/listener/WorkflowStatusListenerStub.java +++ b/core/src/main/java/com/netflix/conductor/core/listener/WorkflowStatusListenerStub.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/metadata/MetadataMapperService.java b/core/src/main/java/com/netflix/conductor/core/metadata/MetadataMapperService.java index 7a825adac..31e4abaca 100644 --- a/core/src/main/java/com/netflix/conductor/core/metadata/MetadataMapperService.java +++ b/core/src/main/java/com/netflix/conductor/core/metadata/MetadataMapperService.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/operation/StartWorkflowOperation.java b/core/src/main/java/com/netflix/conductor/core/operation/StartWorkflowOperation.java index e9281de64..3ac92eb53 100644 --- a/core/src/main/java/com/netflix/conductor/core/operation/StartWorkflowOperation.java +++ b/core/src/main/java/com/netflix/conductor/core/operation/StartWorkflowOperation.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/operation/WorkflowOperation.java b/core/src/main/java/com/netflix/conductor/core/operation/WorkflowOperation.java index c0b428cf9..73a000042 100644 --- a/core/src/main/java/com/netflix/conductor/core/operation/WorkflowOperation.java +++ b/core/src/main/java/com/netflix/conductor/core/operation/WorkflowOperation.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/reconciliation/WorkflowReconciler.java b/core/src/main/java/com/netflix/conductor/core/reconciliation/WorkflowReconciler.java index d5e8fe5db..a95d1920f 100644 --- a/core/src/main/java/com/netflix/conductor/core/reconciliation/WorkflowReconciler.java +++ b/core/src/main/java/com/netflix/conductor/core/reconciliation/WorkflowReconciler.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/reconciliation/WorkflowRepairService.java b/core/src/main/java/com/netflix/conductor/core/reconciliation/WorkflowRepairService.java index 49ca8a632..2266f604f 100644 --- a/core/src/main/java/com/netflix/conductor/core/reconciliation/WorkflowRepairService.java +++ b/core/src/main/java/com/netflix/conductor/core/reconciliation/WorkflowRepairService.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/reconciliation/WorkflowSweeper.java b/core/src/main/java/com/netflix/conductor/core/reconciliation/WorkflowSweeper.java index cd4b46be7..a83ea4d39 100644 --- a/core/src/main/java/com/netflix/conductor/core/reconciliation/WorkflowSweeper.java +++ b/core/src/main/java/com/netflix/conductor/core/reconciliation/WorkflowSweeper.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/storage/DummyPayloadStorage.java b/core/src/main/java/com/netflix/conductor/core/storage/DummyPayloadStorage.java index a04a43710..a083405eb 100644 --- a/core/src/main/java/com/netflix/conductor/core/storage/DummyPayloadStorage.java +++ b/core/src/main/java/com/netflix/conductor/core/storage/DummyPayloadStorage.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/sync/Lock.java b/core/src/main/java/com/netflix/conductor/core/sync/Lock.java index cb8d5ccd4..b219d41f2 100644 --- a/core/src/main/java/com/netflix/conductor/core/sync/Lock.java +++ b/core/src/main/java/com/netflix/conductor/core/sync/Lock.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/sync/local/LocalOnlyLock.java b/core/src/main/java/com/netflix/conductor/core/sync/local/LocalOnlyLock.java index 17cbee4fe..97408257b 100644 --- a/core/src/main/java/com/netflix/conductor/core/sync/local/LocalOnlyLock.java +++ b/core/src/main/java/com/netflix/conductor/core/sync/local/LocalOnlyLock.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/sync/local/LocalOnlyLockConfiguration.java b/core/src/main/java/com/netflix/conductor/core/sync/local/LocalOnlyLockConfiguration.java index 41a025406..790fda65e 100644 --- a/core/src/main/java/com/netflix/conductor/core/sync/local/LocalOnlyLockConfiguration.java +++ b/core/src/main/java/com/netflix/conductor/core/sync/local/LocalOnlyLockConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/sync/noop/NoopLock.java b/core/src/main/java/com/netflix/conductor/core/sync/noop/NoopLock.java index 5d492da1e..e372b26f7 100644 --- a/core/src/main/java/com/netflix/conductor/core/sync/noop/NoopLock.java +++ b/core/src/main/java/com/netflix/conductor/core/sync/noop/NoopLock.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/utils/DateTimeUtils.java b/core/src/main/java/com/netflix/conductor/core/utils/DateTimeUtils.java index ec7ce83f0..7da8e43e8 100644 --- a/core/src/main/java/com/netflix/conductor/core/utils/DateTimeUtils.java +++ b/core/src/main/java/com/netflix/conductor/core/utils/DateTimeUtils.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/utils/ExternalPayloadStorageUtils.java b/core/src/main/java/com/netflix/conductor/core/utils/ExternalPayloadStorageUtils.java index 7cbc80e9e..e9ff71f1a 100644 --- a/core/src/main/java/com/netflix/conductor/core/utils/ExternalPayloadStorageUtils.java +++ b/core/src/main/java/com/netflix/conductor/core/utils/ExternalPayloadStorageUtils.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/utils/IDGenerator.java b/core/src/main/java/com/netflix/conductor/core/utils/IDGenerator.java index 813d63aa9..0f9060416 100644 --- a/core/src/main/java/com/netflix/conductor/core/utils/IDGenerator.java +++ b/core/src/main/java/com/netflix/conductor/core/utils/IDGenerator.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/utils/JsonUtils.java b/core/src/main/java/com/netflix/conductor/core/utils/JsonUtils.java index 38f70218c..2ec74e5a3 100644 --- a/core/src/main/java/com/netflix/conductor/core/utils/JsonUtils.java +++ b/core/src/main/java/com/netflix/conductor/core/utils/JsonUtils.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/utils/ParametersUtils.java b/core/src/main/java/com/netflix/conductor/core/utils/ParametersUtils.java index 15f8363f6..199dbac47 100644 --- a/core/src/main/java/com/netflix/conductor/core/utils/ParametersUtils.java +++ b/core/src/main/java/com/netflix/conductor/core/utils/ParametersUtils.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/utils/QueueUtils.java b/core/src/main/java/com/netflix/conductor/core/utils/QueueUtils.java index bca477390..0fa463d93 100644 --- a/core/src/main/java/com/netflix/conductor/core/utils/QueueUtils.java +++ b/core/src/main/java/com/netflix/conductor/core/utils/QueueUtils.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/utils/SemaphoreUtil.java b/core/src/main/java/com/netflix/conductor/core/utils/SemaphoreUtil.java index 793494bd9..df4d23120 100644 --- a/core/src/main/java/com/netflix/conductor/core/utils/SemaphoreUtil.java +++ b/core/src/main/java/com/netflix/conductor/core/utils/SemaphoreUtil.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/core/utils/Utils.java b/core/src/main/java/com/netflix/conductor/core/utils/Utils.java index e81b3cf58..2464d996b 100644 --- a/core/src/main/java/com/netflix/conductor/core/utils/Utils.java +++ b/core/src/main/java/com/netflix/conductor/core/utils/Utils.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/dao/ConcurrentExecutionLimitDAO.java b/core/src/main/java/com/netflix/conductor/dao/ConcurrentExecutionLimitDAO.java index 853a72e63..5ca70c6b0 100644 --- a/core/src/main/java/com/netflix/conductor/dao/ConcurrentExecutionLimitDAO.java +++ b/core/src/main/java/com/netflix/conductor/dao/ConcurrentExecutionLimitDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/dao/EventHandlerDAO.java b/core/src/main/java/com/netflix/conductor/dao/EventHandlerDAO.java index 6c9dc47a9..5d4812190 100644 --- a/core/src/main/java/com/netflix/conductor/dao/EventHandlerDAO.java +++ b/core/src/main/java/com/netflix/conductor/dao/EventHandlerDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/dao/ExecutionDAO.java b/core/src/main/java/com/netflix/conductor/dao/ExecutionDAO.java index 8e33cac29..b94ffaf59 100644 --- a/core/src/main/java/com/netflix/conductor/dao/ExecutionDAO.java +++ b/core/src/main/java/com/netflix/conductor/dao/ExecutionDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/dao/IndexDAO.java b/core/src/main/java/com/netflix/conductor/dao/IndexDAO.java index 14e53b2ab..ed3ada875 100644 --- a/core/src/main/java/com/netflix/conductor/dao/IndexDAO.java +++ b/core/src/main/java/com/netflix/conductor/dao/IndexDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/dao/MetadataDAO.java b/core/src/main/java/com/netflix/conductor/dao/MetadataDAO.java index b7e39cf3a..712096cd3 100644 --- a/core/src/main/java/com/netflix/conductor/dao/MetadataDAO.java +++ b/core/src/main/java/com/netflix/conductor/dao/MetadataDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/dao/PollDataDAO.java b/core/src/main/java/com/netflix/conductor/dao/PollDataDAO.java index d53d6660d..7a1230d6c 100644 --- a/core/src/main/java/com/netflix/conductor/dao/PollDataDAO.java +++ b/core/src/main/java/com/netflix/conductor/dao/PollDataDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/dao/QueueDAO.java b/core/src/main/java/com/netflix/conductor/dao/QueueDAO.java index 70b5857c5..eccfe07b0 100644 --- a/core/src/main/java/com/netflix/conductor/dao/QueueDAO.java +++ b/core/src/main/java/com/netflix/conductor/dao/QueueDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/dao/RateLimitingDAO.java b/core/src/main/java/com/netflix/conductor/dao/RateLimitingDAO.java index 6ef4b4859..65ad25fa0 100644 --- a/core/src/main/java/com/netflix/conductor/dao/RateLimitingDAO.java +++ b/core/src/main/java/com/netflix/conductor/dao/RateLimitingDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/metrics/Monitors.java b/core/src/main/java/com/netflix/conductor/metrics/Monitors.java index 862d3076d..cbe529ae4 100644 --- a/core/src/main/java/com/netflix/conductor/metrics/Monitors.java +++ b/core/src/main/java/com/netflix/conductor/metrics/Monitors.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/metrics/WorkflowMonitor.java b/core/src/main/java/com/netflix/conductor/metrics/WorkflowMonitor.java index 2f974ed68..e1e8fc637 100644 --- a/core/src/main/java/com/netflix/conductor/metrics/WorkflowMonitor.java +++ b/core/src/main/java/com/netflix/conductor/metrics/WorkflowMonitor.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/model/TaskModel.java b/core/src/main/java/com/netflix/conductor/model/TaskModel.java index 617b013da..59875ac43 100644 --- a/core/src/main/java/com/netflix/conductor/model/TaskModel.java +++ b/core/src/main/java/com/netflix/conductor/model/TaskModel.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/model/WorkflowModel.java b/core/src/main/java/com/netflix/conductor/model/WorkflowModel.java index ca505aa9c..c0bfffccd 100644 --- a/core/src/main/java/com/netflix/conductor/model/WorkflowModel.java +++ b/core/src/main/java/com/netflix/conductor/model/WorkflowModel.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/service/AdminService.java b/core/src/main/java/com/netflix/conductor/service/AdminService.java index 474743db4..973a3edc8 100644 --- a/core/src/main/java/com/netflix/conductor/service/AdminService.java +++ b/core/src/main/java/com/netflix/conductor/service/AdminService.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/service/AdminServiceImpl.java b/core/src/main/java/com/netflix/conductor/service/AdminServiceImpl.java index bf470d4e8..8c11dd94b 100644 --- a/core/src/main/java/com/netflix/conductor/service/AdminServiceImpl.java +++ b/core/src/main/java/com/netflix/conductor/service/AdminServiceImpl.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/service/EventService.java b/core/src/main/java/com/netflix/conductor/service/EventService.java index 397503cf4..3d42a872b 100644 --- a/core/src/main/java/com/netflix/conductor/service/EventService.java +++ b/core/src/main/java/com/netflix/conductor/service/EventService.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/service/EventServiceImpl.java b/core/src/main/java/com/netflix/conductor/service/EventServiceImpl.java index b4b20bdf3..579986e11 100644 --- a/core/src/main/java/com/netflix/conductor/service/EventServiceImpl.java +++ b/core/src/main/java/com/netflix/conductor/service/EventServiceImpl.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/service/ExecutionLockService.java b/core/src/main/java/com/netflix/conductor/service/ExecutionLockService.java index c45bba263..b7539ca4d 100644 --- a/core/src/main/java/com/netflix/conductor/service/ExecutionLockService.java +++ b/core/src/main/java/com/netflix/conductor/service/ExecutionLockService.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/service/ExecutionService.java b/core/src/main/java/com/netflix/conductor/service/ExecutionService.java index a4e411b4e..a33f1814b 100644 --- a/core/src/main/java/com/netflix/conductor/service/ExecutionService.java +++ b/core/src/main/java/com/netflix/conductor/service/ExecutionService.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/service/MetadataService.java b/core/src/main/java/com/netflix/conductor/service/MetadataService.java index babd46627..5edd42ef5 100644 --- a/core/src/main/java/com/netflix/conductor/service/MetadataService.java +++ b/core/src/main/java/com/netflix/conductor/service/MetadataService.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/service/MetadataServiceImpl.java b/core/src/main/java/com/netflix/conductor/service/MetadataServiceImpl.java index 7326ab62d..d48b95a42 100644 --- a/core/src/main/java/com/netflix/conductor/service/MetadataServiceImpl.java +++ b/core/src/main/java/com/netflix/conductor/service/MetadataServiceImpl.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/service/TaskService.java b/core/src/main/java/com/netflix/conductor/service/TaskService.java index d89772659..9d29600ac 100644 --- a/core/src/main/java/com/netflix/conductor/service/TaskService.java +++ b/core/src/main/java/com/netflix/conductor/service/TaskService.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/service/TaskServiceImpl.java b/core/src/main/java/com/netflix/conductor/service/TaskServiceImpl.java index 5c07d5cff..3749e7dfd 100644 --- a/core/src/main/java/com/netflix/conductor/service/TaskServiceImpl.java +++ b/core/src/main/java/com/netflix/conductor/service/TaskServiceImpl.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/service/WorkflowBulkService.java b/core/src/main/java/com/netflix/conductor/service/WorkflowBulkService.java index e54c94f60..de6bd4292 100644 --- a/core/src/main/java/com/netflix/conductor/service/WorkflowBulkService.java +++ b/core/src/main/java/com/netflix/conductor/service/WorkflowBulkService.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/service/WorkflowBulkServiceImpl.java b/core/src/main/java/com/netflix/conductor/service/WorkflowBulkServiceImpl.java index c637b8bd9..5e05ae453 100644 --- a/core/src/main/java/com/netflix/conductor/service/WorkflowBulkServiceImpl.java +++ b/core/src/main/java/com/netflix/conductor/service/WorkflowBulkServiceImpl.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/service/WorkflowService.java b/core/src/main/java/com/netflix/conductor/service/WorkflowService.java index 6ba2d7e64..2253cad54 100644 --- a/core/src/main/java/com/netflix/conductor/service/WorkflowService.java +++ b/core/src/main/java/com/netflix/conductor/service/WorkflowService.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/service/WorkflowServiceImpl.java b/core/src/main/java/com/netflix/conductor/service/WorkflowServiceImpl.java index 99732a23a..93777afd5 100644 --- a/core/src/main/java/com/netflix/conductor/service/WorkflowServiceImpl.java +++ b/core/src/main/java/com/netflix/conductor/service/WorkflowServiceImpl.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/service/WorkflowTestService.java b/core/src/main/java/com/netflix/conductor/service/WorkflowTestService.java index 9dc3d334f..601c0aba8 100644 --- a/core/src/main/java/com/netflix/conductor/service/WorkflowTestService.java +++ b/core/src/main/java/com/netflix/conductor/service/WorkflowTestService.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/validations/ValidationContext.java b/core/src/main/java/com/netflix/conductor/validations/ValidationContext.java index 56fbb22d3..6bf5ed000 100644 --- a/core/src/main/java/com/netflix/conductor/validations/ValidationContext.java +++ b/core/src/main/java/com/netflix/conductor/validations/ValidationContext.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/main/java/com/netflix/conductor/validations/WorkflowTaskTypeConstraint.java b/core/src/main/java/com/netflix/conductor/validations/WorkflowTaskTypeConstraint.java index 2501849be..290d8692b 100644 --- a/core/src/main/java/com/netflix/conductor/validations/WorkflowTaskTypeConstraint.java +++ b/core/src/main/java/com/netflix/conductor/validations/WorkflowTaskTypeConstraint.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/groovy/com/netflix/conductor/core/execution/AsyncSystemTaskExecutorTest.groovy b/core/src/test/groovy/com/netflix/conductor/core/execution/AsyncSystemTaskExecutorTest.groovy index d960eb2b5..69a68d7fb 100644 --- a/core/src/test/groovy/com/netflix/conductor/core/execution/AsyncSystemTaskExecutorTest.groovy +++ b/core/src/test/groovy/com/netflix/conductor/core/execution/AsyncSystemTaskExecutorTest.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/groovy/com/netflix/conductor/core/execution/tasks/DoWhileSpec.groovy b/core/src/test/groovy/com/netflix/conductor/core/execution/tasks/DoWhileSpec.groovy index f2bd2632c..8c6f77539 100644 --- a/core/src/test/groovy/com/netflix/conductor/core/execution/tasks/DoWhileSpec.groovy +++ b/core/src/test/groovy/com/netflix/conductor/core/execution/tasks/DoWhileSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/groovy/com/netflix/conductor/core/execution/tasks/EventSpec.groovy b/core/src/test/groovy/com/netflix/conductor/core/execution/tasks/EventSpec.groovy index 837b81b16..e0ba3ddb1 100644 --- a/core/src/test/groovy/com/netflix/conductor/core/execution/tasks/EventSpec.groovy +++ b/core/src/test/groovy/com/netflix/conductor/core/execution/tasks/EventSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/groovy/com/netflix/conductor/core/execution/tasks/IsolatedTaskQueueProducerSpec.groovy b/core/src/test/groovy/com/netflix/conductor/core/execution/tasks/IsolatedTaskQueueProducerSpec.groovy index 1dd2eeec1..9daeea0d9 100644 --- a/core/src/test/groovy/com/netflix/conductor/core/execution/tasks/IsolatedTaskQueueProducerSpec.groovy +++ b/core/src/test/groovy/com/netflix/conductor/core/execution/tasks/IsolatedTaskQueueProducerSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/groovy/com/netflix/conductor/core/execution/tasks/StartWorkflowSpec.groovy b/core/src/test/groovy/com/netflix/conductor/core/execution/tasks/StartWorkflowSpec.groovy index 9c6af719d..1ae1a64db 100644 --- a/core/src/test/groovy/com/netflix/conductor/core/execution/tasks/StartWorkflowSpec.groovy +++ b/core/src/test/groovy/com/netflix/conductor/core/execution/tasks/StartWorkflowSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/groovy/com/netflix/conductor/core/operation/StartWorkflowOperationSpec.groovy b/core/src/test/groovy/com/netflix/conductor/core/operation/StartWorkflowOperationSpec.groovy index 88556b5a3..187879586 100644 --- a/core/src/test/groovy/com/netflix/conductor/core/operation/StartWorkflowOperationSpec.groovy +++ b/core/src/test/groovy/com/netflix/conductor/core/operation/StartWorkflowOperationSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/groovy/com/netflix/conductor/model/TaskModelSpec.groovy b/core/src/test/groovy/com/netflix/conductor/model/TaskModelSpec.groovy index c95f8edb6..8938f7411 100644 --- a/core/src/test/groovy/com/netflix/conductor/model/TaskModelSpec.groovy +++ b/core/src/test/groovy/com/netflix/conductor/model/TaskModelSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/groovy/com/netflix/conductor/model/WorkflowModelSpec.groovy b/core/src/test/groovy/com/netflix/conductor/model/WorkflowModelSpec.groovy index 3b7763a23..593f6b608 100644 --- a/core/src/test/groovy/com/netflix/conductor/model/WorkflowModelSpec.groovy +++ b/core/src/test/groovy/com/netflix/conductor/model/WorkflowModelSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/TestUtils.java b/core/src/test/java/com/netflix/conductor/TestUtils.java index 08428322c..2229d3da3 100644 --- a/core/src/test/java/com/netflix/conductor/TestUtils.java +++ b/core/src/test/java/com/netflix/conductor/TestUtils.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/dal/ExecutionDAOFacadeTest.java b/core/src/test/java/com/netflix/conductor/core/dal/ExecutionDAOFacadeTest.java index aceccf2b2..7f9928ffb 100644 --- a/core/src/test/java/com/netflix/conductor/core/dal/ExecutionDAOFacadeTest.java +++ b/core/src/test/java/com/netflix/conductor/core/dal/ExecutionDAOFacadeTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/events/MockObservableQueue.java b/core/src/test/java/com/netflix/conductor/core/events/MockObservableQueue.java index 9391aea63..79d4706cb 100644 --- a/core/src/test/java/com/netflix/conductor/core/events/MockObservableQueue.java +++ b/core/src/test/java/com/netflix/conductor/core/events/MockObservableQueue.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/events/MockQueueProvider.java b/core/src/test/java/com/netflix/conductor/core/events/MockQueueProvider.java index cad61a9bd..3900a4501 100644 --- a/core/src/test/java/com/netflix/conductor/core/events/MockQueueProvider.java +++ b/core/src/test/java/com/netflix/conductor/core/events/MockQueueProvider.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/events/TestDefaultEventProcessor.java b/core/src/test/java/com/netflix/conductor/core/events/TestDefaultEventProcessor.java index e3a7351e8..234260899 100644 --- a/core/src/test/java/com/netflix/conductor/core/events/TestDefaultEventProcessor.java +++ b/core/src/test/java/com/netflix/conductor/core/events/TestDefaultEventProcessor.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/events/TestScriptEval.java b/core/src/test/java/com/netflix/conductor/core/events/TestScriptEval.java index 2078b7c99..313c02bc3 100644 --- a/core/src/test/java/com/netflix/conductor/core/events/TestScriptEval.java +++ b/core/src/test/java/com/netflix/conductor/core/events/TestScriptEval.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/events/TestSimpleActionProcessor.java b/core/src/test/java/com/netflix/conductor/core/events/TestSimpleActionProcessor.java index ff446adaf..cd9e62290 100644 --- a/core/src/test/java/com/netflix/conductor/core/events/TestSimpleActionProcessor.java +++ b/core/src/test/java/com/netflix/conductor/core/events/TestSimpleActionProcessor.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/TestDeciderOutcomes.java b/core/src/test/java/com/netflix/conductor/core/execution/TestDeciderOutcomes.java index dbf0277f6..d06029020 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/TestDeciderOutcomes.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/TestDeciderOutcomes.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/TestDeciderService.java b/core/src/test/java/com/netflix/conductor/core/execution/TestDeciderService.java index 133010f83..7e78aee4e 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/TestDeciderService.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/TestDeciderService.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/TestWorkflowDef.java b/core/src/test/java/com/netflix/conductor/core/execution/TestWorkflowDef.java index 2556e55d0..7df603727 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/TestWorkflowDef.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/TestWorkflowDef.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/TestWorkflowExecutor.java b/core/src/test/java/com/netflix/conductor/core/execution/TestWorkflowExecutor.java index bc3da8c60..b974c5c95 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/TestWorkflowExecutor.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/TestWorkflowExecutor.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/WorkflowSystemTaskStub.java b/core/src/test/java/com/netflix/conductor/core/execution/WorkflowSystemTaskStub.java index 3175a248e..2f4be6c17 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/WorkflowSystemTaskStub.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/WorkflowSystemTaskStub.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/mapper/DecisionTaskMapperTest.java b/core/src/test/java/com/netflix/conductor/core/execution/mapper/DecisionTaskMapperTest.java index cdacc2a25..36c115121 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/mapper/DecisionTaskMapperTest.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/mapper/DecisionTaskMapperTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/mapper/DoWhileTaskMapperTest.java b/core/src/test/java/com/netflix/conductor/core/execution/mapper/DoWhileTaskMapperTest.java index f636b4547..1855693aa 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/mapper/DoWhileTaskMapperTest.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/mapper/DoWhileTaskMapperTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/mapper/DynamicTaskMapperTest.java b/core/src/test/java/com/netflix/conductor/core/execution/mapper/DynamicTaskMapperTest.java index 8066db338..936d262f1 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/mapper/DynamicTaskMapperTest.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/mapper/DynamicTaskMapperTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/mapper/EventTaskMapperTest.java b/core/src/test/java/com/netflix/conductor/core/execution/mapper/EventTaskMapperTest.java index 9e5daa1a6..0a7db93ad 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/mapper/EventTaskMapperTest.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/mapper/EventTaskMapperTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/mapper/ForkJoinDynamicTaskMapperTest.java b/core/src/test/java/com/netflix/conductor/core/execution/mapper/ForkJoinDynamicTaskMapperTest.java index 7c7f74796..83d5bac06 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/mapper/ForkJoinDynamicTaskMapperTest.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/mapper/ForkJoinDynamicTaskMapperTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/mapper/ForkJoinTaskMapperTest.java b/core/src/test/java/com/netflix/conductor/core/execution/mapper/ForkJoinTaskMapperTest.java index e42270fd2..e3d2c2f70 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/mapper/ForkJoinTaskMapperTest.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/mapper/ForkJoinTaskMapperTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/mapper/HTTPTaskMapperTest.java b/core/src/test/java/com/netflix/conductor/core/execution/mapper/HTTPTaskMapperTest.java index da548e531..975a7fe70 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/mapper/HTTPTaskMapperTest.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/mapper/HTTPTaskMapperTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/mapper/HumanTaskMapperTest.java b/core/src/test/java/com/netflix/conductor/core/execution/mapper/HumanTaskMapperTest.java index 2c3be681c..d42cd688b 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/mapper/HumanTaskMapperTest.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/mapper/HumanTaskMapperTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/mapper/InlineTaskMapperTest.java b/core/src/test/java/com/netflix/conductor/core/execution/mapper/InlineTaskMapperTest.java index 0c6c11872..42bc050e1 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/mapper/InlineTaskMapperTest.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/mapper/InlineTaskMapperTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/mapper/JoinTaskMapperTest.java b/core/src/test/java/com/netflix/conductor/core/execution/mapper/JoinTaskMapperTest.java index 4e3be843b..ba6d00c0b 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/mapper/JoinTaskMapperTest.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/mapper/JoinTaskMapperTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/mapper/JsonJQTransformTaskMapperTest.java b/core/src/test/java/com/netflix/conductor/core/execution/mapper/JsonJQTransformTaskMapperTest.java index ed4d187b1..947594459 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/mapper/JsonJQTransformTaskMapperTest.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/mapper/JsonJQTransformTaskMapperTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/mapper/KafkaPublishTaskMapperTest.java b/core/src/test/java/com/netflix/conductor/core/execution/mapper/KafkaPublishTaskMapperTest.java index bd7dd268e..052479fc4 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/mapper/KafkaPublishTaskMapperTest.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/mapper/KafkaPublishTaskMapperTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/mapper/LambdaTaskMapperTest.java b/core/src/test/java/com/netflix/conductor/core/execution/mapper/LambdaTaskMapperTest.java index edeef004e..4ec34f59d 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/mapper/LambdaTaskMapperTest.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/mapper/LambdaTaskMapperTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/mapper/NoopTaskMapperTest.java b/core/src/test/java/com/netflix/conductor/core/execution/mapper/NoopTaskMapperTest.java index 6c89af44f..13f67236b 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/mapper/NoopTaskMapperTest.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/mapper/NoopTaskMapperTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/mapper/SetVariableTaskMapperTest.java b/core/src/test/java/com/netflix/conductor/core/execution/mapper/SetVariableTaskMapperTest.java index 8d35c00ee..848c67ace 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/mapper/SetVariableTaskMapperTest.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/mapper/SetVariableTaskMapperTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/mapper/SimpleTaskMapperTest.java b/core/src/test/java/com/netflix/conductor/core/execution/mapper/SimpleTaskMapperTest.java index e3cc14d3c..bebf2e249 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/mapper/SimpleTaskMapperTest.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/mapper/SimpleTaskMapperTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/mapper/SubWorkflowTaskMapperTest.java b/core/src/test/java/com/netflix/conductor/core/execution/mapper/SubWorkflowTaskMapperTest.java index 9681bc2ea..aac93a104 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/mapper/SubWorkflowTaskMapperTest.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/mapper/SubWorkflowTaskMapperTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/mapper/SwitchTaskMapperTest.java b/core/src/test/java/com/netflix/conductor/core/execution/mapper/SwitchTaskMapperTest.java index 256c58b89..7f76ced6e 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/mapper/SwitchTaskMapperTest.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/mapper/SwitchTaskMapperTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/mapper/TerminateTaskMapperTest.java b/core/src/test/java/com/netflix/conductor/core/execution/mapper/TerminateTaskMapperTest.java index 47e02a12e..b7b4fad3e 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/mapper/TerminateTaskMapperTest.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/mapper/TerminateTaskMapperTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/mapper/UserDefinedTaskMapperTest.java b/core/src/test/java/com/netflix/conductor/core/execution/mapper/UserDefinedTaskMapperTest.java index afdafa28d..b465b1fa6 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/mapper/UserDefinedTaskMapperTest.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/mapper/UserDefinedTaskMapperTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/mapper/WaitTaskMapperTest.java b/core/src/test/java/com/netflix/conductor/core/execution/mapper/WaitTaskMapperTest.java index a1f2662db..ddc813f59 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/mapper/WaitTaskMapperTest.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/mapper/WaitTaskMapperTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/tasks/EventQueueResolutionTest.java b/core/src/test/java/com/netflix/conductor/core/execution/tasks/EventQueueResolutionTest.java index 2e9ac328c..1e0d5d79c 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/tasks/EventQueueResolutionTest.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/tasks/EventQueueResolutionTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/tasks/InlineTest.java b/core/src/test/java/com/netflix/conductor/core/execution/tasks/InlineTest.java index 50ef79f14..51cfec7c0 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/tasks/InlineTest.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/tasks/InlineTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/tasks/TestLambda.java b/core/src/test/java/com/netflix/conductor/core/execution/tasks/TestLambda.java index b6a857fbe..0d9b03017 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/tasks/TestLambda.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/tasks/TestLambda.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/tasks/TestNoop.java b/core/src/test/java/com/netflix/conductor/core/execution/tasks/TestNoop.java index 1767f84ec..d6f34dd59 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/tasks/TestNoop.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/tasks/TestNoop.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/tasks/TestSubWorkflow.java b/core/src/test/java/com/netflix/conductor/core/execution/tasks/TestSubWorkflow.java index 61b735d2c..2d5fcccd8 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/tasks/TestSubWorkflow.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/tasks/TestSubWorkflow.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/tasks/TestSystemTaskWorker.java b/core/src/test/java/com/netflix/conductor/core/execution/tasks/TestSystemTaskWorker.java index 5e11fb6ee..bdee32b7c 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/tasks/TestSystemTaskWorker.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/tasks/TestSystemTaskWorker.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/tasks/TestSystemTaskWorkerCoordinator.java b/core/src/test/java/com/netflix/conductor/core/execution/tasks/TestSystemTaskWorkerCoordinator.java index 346b15c5b..9e04e8d70 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/tasks/TestSystemTaskWorkerCoordinator.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/tasks/TestSystemTaskWorkerCoordinator.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/execution/tasks/TestTerminate.java b/core/src/test/java/com/netflix/conductor/core/execution/tasks/TestTerminate.java index 7ecf0d9d2..183153889 100644 --- a/core/src/test/java/com/netflix/conductor/core/execution/tasks/TestTerminate.java +++ b/core/src/test/java/com/netflix/conductor/core/execution/tasks/TestTerminate.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/metadata/MetadataMapperServiceTest.java b/core/src/test/java/com/netflix/conductor/core/metadata/MetadataMapperServiceTest.java index e431a16e6..1999dfbfa 100644 --- a/core/src/test/java/com/netflix/conductor/core/metadata/MetadataMapperServiceTest.java +++ b/core/src/test/java/com/netflix/conductor/core/metadata/MetadataMapperServiceTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/reconciliation/TestWorkflowRepairService.java b/core/src/test/java/com/netflix/conductor/core/reconciliation/TestWorkflowRepairService.java index 7c3859bcd..54f17fec4 100644 --- a/core/src/test/java/com/netflix/conductor/core/reconciliation/TestWorkflowRepairService.java +++ b/core/src/test/java/com/netflix/conductor/core/reconciliation/TestWorkflowRepairService.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/reconciliation/TestWorkflowSweeper.java b/core/src/test/java/com/netflix/conductor/core/reconciliation/TestWorkflowSweeper.java index 7951d5e92..5accfb580 100644 --- a/core/src/test/java/com/netflix/conductor/core/reconciliation/TestWorkflowSweeper.java +++ b/core/src/test/java/com/netflix/conductor/core/reconciliation/TestWorkflowSweeper.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/storage/DummyPayloadStorageTest.java b/core/src/test/java/com/netflix/conductor/core/storage/DummyPayloadStorageTest.java index e5fd2c04d..30a42c8ad 100644 --- a/core/src/test/java/com/netflix/conductor/core/storage/DummyPayloadStorageTest.java +++ b/core/src/test/java/com/netflix/conductor/core/storage/DummyPayloadStorageTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/sync/local/LocalOnlyLockTest.java b/core/src/test/java/com/netflix/conductor/core/sync/local/LocalOnlyLockTest.java index 7fc95a54c..a9b7dbba2 100644 --- a/core/src/test/java/com/netflix/conductor/core/sync/local/LocalOnlyLockTest.java +++ b/core/src/test/java/com/netflix/conductor/core/sync/local/LocalOnlyLockTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/utils/ExternalPayloadStorageUtilsTest.java b/core/src/test/java/com/netflix/conductor/core/utils/ExternalPayloadStorageUtilsTest.java index a093045d6..dbd4557bc 100644 --- a/core/src/test/java/com/netflix/conductor/core/utils/ExternalPayloadStorageUtilsTest.java +++ b/core/src/test/java/com/netflix/conductor/core/utils/ExternalPayloadStorageUtilsTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/utils/JsonUtilsTest.java b/core/src/test/java/com/netflix/conductor/core/utils/JsonUtilsTest.java index bc467b1a2..18ca51135 100644 --- a/core/src/test/java/com/netflix/conductor/core/utils/JsonUtilsTest.java +++ b/core/src/test/java/com/netflix/conductor/core/utils/JsonUtilsTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/utils/ParametersUtilsTest.java b/core/src/test/java/com/netflix/conductor/core/utils/ParametersUtilsTest.java index 2f3c20751..719972234 100644 --- a/core/src/test/java/com/netflix/conductor/core/utils/ParametersUtilsTest.java +++ b/core/src/test/java/com/netflix/conductor/core/utils/ParametersUtilsTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/utils/QueueUtilsTest.java b/core/src/test/java/com/netflix/conductor/core/utils/QueueUtilsTest.java index 6633c5fa8..277625a39 100644 --- a/core/src/test/java/com/netflix/conductor/core/utils/QueueUtilsTest.java +++ b/core/src/test/java/com/netflix/conductor/core/utils/QueueUtilsTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/core/utils/SemaphoreUtilTest.java b/core/src/test/java/com/netflix/conductor/core/utils/SemaphoreUtilTest.java index 21b03e190..9afb56d96 100644 --- a/core/src/test/java/com/netflix/conductor/core/utils/SemaphoreUtilTest.java +++ b/core/src/test/java/com/netflix/conductor/core/utils/SemaphoreUtilTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/dao/ExecutionDAOTest.java b/core/src/test/java/com/netflix/conductor/dao/ExecutionDAOTest.java index be49cce25..7fcbede8f 100644 --- a/core/src/test/java/com/netflix/conductor/dao/ExecutionDAOTest.java +++ b/core/src/test/java/com/netflix/conductor/dao/ExecutionDAOTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/dao/PollDataDAOTest.java b/core/src/test/java/com/netflix/conductor/dao/PollDataDAOTest.java index 97f4406b3..856ce6c41 100644 --- a/core/src/test/java/com/netflix/conductor/dao/PollDataDAOTest.java +++ b/core/src/test/java/com/netflix/conductor/dao/PollDataDAOTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/metrics/WorkflowMonitorTest.java b/core/src/test/java/com/netflix/conductor/metrics/WorkflowMonitorTest.java index 120130076..15917c088 100644 --- a/core/src/test/java/com/netflix/conductor/metrics/WorkflowMonitorTest.java +++ b/core/src/test/java/com/netflix/conductor/metrics/WorkflowMonitorTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/service/EventServiceTest.java b/core/src/test/java/com/netflix/conductor/service/EventServiceTest.java index 86a61e6ad..ce96ce874 100644 --- a/core/src/test/java/com/netflix/conductor/service/EventServiceTest.java +++ b/core/src/test/java/com/netflix/conductor/service/EventServiceTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/service/ExecutionServiceTest.java b/core/src/test/java/com/netflix/conductor/service/ExecutionServiceTest.java index d767641ff..9c7a631e3 100644 --- a/core/src/test/java/com/netflix/conductor/service/ExecutionServiceTest.java +++ b/core/src/test/java/com/netflix/conductor/service/ExecutionServiceTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/service/MetadataServiceTest.java b/core/src/test/java/com/netflix/conductor/service/MetadataServiceTest.java index eed4afb4d..1fa3f1990 100644 --- a/core/src/test/java/com/netflix/conductor/service/MetadataServiceTest.java +++ b/core/src/test/java/com/netflix/conductor/service/MetadataServiceTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/service/TaskServiceTest.java b/core/src/test/java/com/netflix/conductor/service/TaskServiceTest.java index 240b99e8c..ab06440f7 100644 --- a/core/src/test/java/com/netflix/conductor/service/TaskServiceTest.java +++ b/core/src/test/java/com/netflix/conductor/service/TaskServiceTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/service/WorkflowBulkServiceTest.java b/core/src/test/java/com/netflix/conductor/service/WorkflowBulkServiceTest.java index 1936401f1..27c23b992 100644 --- a/core/src/test/java/com/netflix/conductor/service/WorkflowBulkServiceTest.java +++ b/core/src/test/java/com/netflix/conductor/service/WorkflowBulkServiceTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/service/WorkflowServiceTest.java b/core/src/test/java/com/netflix/conductor/service/WorkflowServiceTest.java index 772f2f2e9..226d51e03 100644 --- a/core/src/test/java/com/netflix/conductor/service/WorkflowServiceTest.java +++ b/core/src/test/java/com/netflix/conductor/service/WorkflowServiceTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/validations/WorkflowDefConstraintTest.java b/core/src/test/java/com/netflix/conductor/validations/WorkflowDefConstraintTest.java index c66ed56df..655b4d75e 100644 --- a/core/src/test/java/com/netflix/conductor/validations/WorkflowDefConstraintTest.java +++ b/core/src/test/java/com/netflix/conductor/validations/WorkflowDefConstraintTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/core/src/test/java/com/netflix/conductor/validations/WorkflowTaskTypeConstraintTest.java b/core/src/test/java/com/netflix/conductor/validations/WorkflowTaskTypeConstraintTest.java index 84d2bcd59..eb1d88dd3 100644 --- a/core/src/test/java/com/netflix/conductor/validations/WorkflowTaskTypeConstraintTest.java +++ b/core/src/test/java/com/netflix/conductor/validations/WorkflowTaskTypeConstraintTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/docs/docs/resources/contributing.md b/docs/docs/resources/contributing.md deleted file mode 100644 index 89af84735..000000000 --- a/docs/docs/resources/contributing.md +++ /dev/null @@ -1,73 +0,0 @@ -# Contributing -Thanks for your interest in Conductor! -This guide helps to find the most efficient way to contribute, ask questions, and report issues. - -Code of conduct ------ - -Please review our [code of conduct](code-of-conduct.md). - -I have a question! ------ - -We have a dedicated [discussion forum](https://github.com/Netflix/conductor/discussions) for asking "how to" questions and to discuss ideas. The discussion forum is a great place to start if you're considering creating a feature request or work on a Pull Request. -*Please do not create issues to ask questions.* - -I want to contribute! ------- - -We welcome Pull Requests and already had many outstanding community contributions! -Creating and reviewing Pull Requests take considerable time. This section helps you to set up a smooth Pull Request experience. - -The stable branch is [main](https://github.com/Netflix/conductor/tree/main). - -Please create pull requests for your contributions against [main](https://github.com/Netflix/conductor/tree/main) only. - -It's a great idea to discuss the new feature you're considering on the [discussion forum](https://github.com/Netflix/conductor/discussions) before writing any code. There are often different ways you can implement a feature. Getting some discussion about different options helps shape the best solution. When starting directly with a Pull Request, there is the risk of having to make considerable changes. Sometimes that is the best approach, though! Showing an idea with code can be very helpful; be aware that it might be throw-away work. Some of our best Pull Requests came out of multiple competing implementations, which helped shape it to perfection. - -Also, consider that not every feature is a good fit for Conductor. A few things to consider are: - -* Is it increasing complexity for the user, or might it be confusing? -* Does it, in any way, break backward compatibility (this is seldom acceptable) -* Does it require new dependencies (this is rarely acceptable for core modules) -* Should the feature be opt-in or enabled by default. For integration with a new Queuing recipe or persistence module, a separate module which can be optionally enabled is the right choice. -* Should the feature be implemented in the main Conductor repository, or would it be better to set up a separate repository? Especially for integration with other systems, a separate repository is often the right choice because the life-cycle of it will be different. - -Of course, for more minor bug fixes and improvements, the process can be more light-weight. - -We'll try to be responsive to Pull Requests. Do keep in mind that because of the inherently distributed nature of open source projects, responses to a PR might take some time because of time zones, weekends, and other things we may be working on. - -I want to report an issue ------ - -If you found a bug, it is much appreciated if you create an issue. Please include clear instructions on how to reproduce the issue, or even better, include a test case on a branch. Make sure to come up with a descriptive title for the issue because this helps while organizing issues. - -I have a great idea for a new feature ----- -Many features in Conductor have come from ideas from the community. If you think something is missing or certain use cases could be supported better, let us know! You can do so by opening a discussion on the [discussion forum](https://github.com/Netflix/conductor/discussions). Provide as much relevant context to why and when the feature would be helpful. Providing context is especially important for "Support XYZ" issues since we might not be familiar with what "XYZ" is and why it's useful. If you have an idea of how to implement the feature, include that as well. - -Once we have decided on a direction, it's time to summarize the idea by creating a new issue. - -## Code Style -We use [spotless](https://github.com/diffplug/spotless) to enforce consistent code style for the project, so make sure to run `gradlew spotlessApply` to fix any violations after code changes. - -## License - -By contributing your code, you agree to license your contribution under the terms of the APLv2: https://github.com/Netflix/conductor/blob/master/LICENSE - -All files are released with the Apache 2.0 license, and the following license header will be automatically added to your new file if none present: - -``` -/** - * Copyright $YEAR Netflix, Inc. - * - * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with - * the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on - * an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the - * specific language governing permissions and limitations under the License. - */ -``` diff --git a/docs/docs/resources/license.md b/docs/docs/resources/license.md deleted file mode 100644 index 518de4064..000000000 --- a/docs/docs/resources/license.md +++ /dev/null @@ -1,15 +0,0 @@ -# License - -Copyright 2022 Netflix, Inc. - -Licensed under the Apache License, Version 2.0 (the "License"); -you may not use this file except in compliance with the License. -You may obtain a copy of the License at - -[http://www.apache.org/licenses/LICENSE-2.0](http://www.apache.org/licenses/LICENSE-2.0) - -Unless required by applicable law or agreed to in writing, software -distributed under the License is distributed on an "AS IS" BASIS, -WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. -See the License for the specific language governing permissions and -limitations under the License. diff --git a/docs/docs/resources/related.md b/docs/docs/resources/related.md deleted file mode 100644 index 9a293f152..000000000 --- a/docs/docs/resources/related.md +++ /dev/null @@ -1,74 +0,0 @@ -# Community projects related to Conductor - -## Client SDKs - -Further, all of the (non-Java) SDKs have a new GitHub home: the Conductor SDK repository is your new source for Conductor SDKs: - -* [Golang](https://github.com/conductor-sdk/conductor-go) -* [Python](https://github.com/conductor-sdk/conductor-python) -* [C#](https://github.com/conductor-sdk/conductor-csharp) -* [Clojure](https://github.com/conductor-sdk/conductor-clojure) - -All contributions on the above client sdks can be made on [Conductor SDK](https://github.com/conductor-sdk) repository. - -## Microservices operations - -* https://github.com/flaviostutz/schellar - Schellar is a scheduler tool for instantiating Conductor workflows from time to time, mostly like a cron job, but with transport of input/output variables between calls. - -* https://github.com/flaviostutz/backtor - Backtor is a backup scheduler tool that uses Conductor workers to handle backup operations and decide when to expire backups (ex.: keep backup 3 days, 2 weeks, 2 months, 1 semester) - -* https://github.com/cquon/conductor-tools - Conductor CLI for launching workflows, polling tasks, listing running tasks etc - - -## Conductor deployment - -* https://github.com/flaviostutz/conductor-server - Docker container for running Conductor with Prometheus metrics plugin installed and some tweaks to ease provisioning of workflows from json files embedded to the container - -* https://github.com/flaviostutz/conductor-ui - Docker container for running Conductor UI so that you can easily scale UI independently - -* https://github.com/flaviostutz/elasticblast - "Elasticsearch to Bleve" bridge tailored for running Conductor on top of Bleve indexer. The footprint of Elasticsearch may cost too much for small deployments on Cloud environment. - -* https://github.com/mohelsaka/conductor-prometheus-metrics - Conductor plugin for exposing Prometheus metrics over path '/metrics' - -## OAuth2.0 Security Configuration -Forked Repository - [Conductor (Secure)](https://github.com/maheshyaddanapudi/conductor/tree/oauth2) - -[OAuth2.0 Role Based Security!](https://github.com/maheshyaddanapudi/conductor/blob/oauth2/SECURITY.md) - Spring Security with easy configuration to secure the Conductor server APIs. - -Docker image published to [Docker Hub](https://hub.docker.com/repository/docker/conductorboot/server) - -## Conductor Worker utilities - -* https://github.com/ggrcha/conductor-go-client - Conductor Golang client for writing Workers in Golang - -* https://github.com/courosh12/conductor-dotnet-client - Conductor DOTNET client for writing Workers in DOTNET - * https://github.com/TwoUnderscorez/serilog-sinks-conductor-task-log - Serilog sink for sending worker log events to Netflix Conductor - -* https://github.com/davidwadden/conductor-workers - Various ready made Conductor workers for common operations on some platforms (ex.: Jira, Github, Concourse) - -## Conductor Web UI - -* https://github.com/maheshyaddanapudi/conductor-ng-ui - Angular based - Conductor Workflow Management UI - -## Conductor Persistence - -### Mongo Persistence - -* https://github.com/maheshyaddanapudi/conductor/tree/mongo_persistence - With option to use Mongo Database as persistence unit. - * Mongo Persistence / Option to use Mongo Database as persistence unit. - * Docker Compose example with MongoDB Container. - -### Oracle Persistence - -* https://github.com/maheshyaddanapudi/conductor/tree/oracle_persistence - With option to use Oracle Database as persistence unit. - * Oracle Persistence / Option to use Oracle Database as persistence unit : version > 12.2 - Tested well with 19C - * Docker Compose example with Oracle Container. - -## Schedule Conductor Workflow -* https://github.com/jas34/scheduledwf - It solves the following problem statements: - * At times there are use cases in which we need to run some tasks/jobs only at a scheduled time. - * In microservice architecture maintaining schedulers in various microservices is a pain. - * We should have a central dedicate service that can do scheduling for us and provide a trigger to a microservices at expected time. -* It offers an additional module `io.github.jas34.scheduledwf.config.ScheduledWfServerModule` built on the existing core -of conductor and does not require deployment of any additional service. -For more details refer: [Schedule Conductor Workflows](https://jas34.github.io/scheduledwf) and [Capability In Conductor To Schedule Workflows](https://github.com/Netflix/conductor/discussions/2256) \ No newline at end of file diff --git a/es6-persistence/build.gradle b/es6-persistence/build.gradle index 9465340f6..5ebed8636 100644 --- a/es6-persistence/build.gradle +++ b/es6-persistence/build.gradle @@ -37,6 +37,6 @@ dependencies { switch (org.gradle.internal.os.OperatingSystem.current()) { case org.gradle.internal.os.OperatingSystem.MAC_OS: - tasks.forEach(task -> task.onlyIf { project.hasProperty('ES6Test') }) + //tasks.forEach(task -> task.onlyIf { project.hasProperty('ES6Test') }) break; -} \ No newline at end of file +} diff --git a/es6-persistence/src/main/java/com/netflix/conductor/es6/config/ElasticSearchConditions.java b/es6-persistence/src/main/java/com/netflix/conductor/es6/config/ElasticSearchConditions.java index e8edae218..069a0e8dc 100644 --- a/es6-persistence/src/main/java/com/netflix/conductor/es6/config/ElasticSearchConditions.java +++ b/es6-persistence/src/main/java/com/netflix/conductor/es6/config/ElasticSearchConditions.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/main/java/com/netflix/conductor/es6/config/ElasticSearchProperties.java b/es6-persistence/src/main/java/com/netflix/conductor/es6/config/ElasticSearchProperties.java index 50500af64..106b5413c 100644 --- a/es6-persistence/src/main/java/com/netflix/conductor/es6/config/ElasticSearchProperties.java +++ b/es6-persistence/src/main/java/com/netflix/conductor/es6/config/ElasticSearchProperties.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/main/java/com/netflix/conductor/es6/config/ElasticSearchV6Configuration.java b/es6-persistence/src/main/java/com/netflix/conductor/es6/config/ElasticSearchV6Configuration.java index a16bea44d..3282c5c26 100644 --- a/es6-persistence/src/main/java/com/netflix/conductor/es6/config/ElasticSearchV6Configuration.java +++ b/es6-persistence/src/main/java/com/netflix/conductor/es6/config/ElasticSearchV6Configuration.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/main/java/com/netflix/conductor/es6/config/IsHttpProtocol.java b/es6-persistence/src/main/java/com/netflix/conductor/es6/config/IsHttpProtocol.java index 2437e1a22..fea331c64 100644 --- a/es6-persistence/src/main/java/com/netflix/conductor/es6/config/IsHttpProtocol.java +++ b/es6-persistence/src/main/java/com/netflix/conductor/es6/config/IsHttpProtocol.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/main/java/com/netflix/conductor/es6/config/IsTcpProtocol.java b/es6-persistence/src/main/java/com/netflix/conductor/es6/config/IsTcpProtocol.java index accf3c468..a0bdadd4b 100644 --- a/es6-persistence/src/main/java/com/netflix/conductor/es6/config/IsTcpProtocol.java +++ b/es6-persistence/src/main/java/com/netflix/conductor/es6/config/IsTcpProtocol.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/index/BulkRequestBuilderWrapper.java b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/index/BulkRequestBuilderWrapper.java index d0056c729..9f9a77362 100644 --- a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/index/BulkRequestBuilderWrapper.java +++ b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/index/BulkRequestBuilderWrapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/index/BulkRequestWrapper.java b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/index/BulkRequestWrapper.java index d33aedf5c..aee726dac 100644 --- a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/index/BulkRequestWrapper.java +++ b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/index/BulkRequestWrapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/index/ElasticSearchBaseDAO.java b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/index/ElasticSearchBaseDAO.java index 38733977e..268c3a002 100644 --- a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/index/ElasticSearchBaseDAO.java +++ b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/index/ElasticSearchBaseDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/index/ElasticSearchDAOV6.java b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/index/ElasticSearchDAOV6.java index bbf05423e..a64ed215d 100644 --- a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/index/ElasticSearchDAOV6.java +++ b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/index/ElasticSearchDAOV6.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/index/ElasticSearchRestDAOV6.java b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/index/ElasticSearchRestDAOV6.java index e51d13341..3fc47d811 100644 --- a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/index/ElasticSearchRestDAOV6.java +++ b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/index/ElasticSearchRestDAOV6.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/Expression.java b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/Expression.java index 9ab2dfe41..5466a2845 100644 --- a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/Expression.java +++ b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/Expression.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/FilterProvider.java b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/FilterProvider.java index 3c145975d..fca92d8b5 100644 --- a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/FilterProvider.java +++ b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/FilterProvider.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/GroupedExpression.java b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/GroupedExpression.java index 90fc3b489..168b6b982 100644 --- a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/GroupedExpression.java +++ b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/GroupedExpression.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/NameValue.java b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/NameValue.java index 68c1e5af2..95e04e2a4 100644 --- a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/NameValue.java +++ b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/NameValue.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/AbstractNode.java b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/AbstractNode.java index 2d5fe84ad..20d4a5b26 100644 --- a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/AbstractNode.java +++ b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/AbstractNode.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/BooleanOp.java b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/BooleanOp.java index ccdc15a55..6f435cd5a 100644 --- a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/BooleanOp.java +++ b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/BooleanOp.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/ComparisonOp.java b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/ComparisonOp.java index 10d44863d..66450ead0 100644 --- a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/ComparisonOp.java +++ b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/ComparisonOp.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/ConstValue.java b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/ConstValue.java index 47bebce6b..080330cb7 100644 --- a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/ConstValue.java +++ b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/ConstValue.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/FunctionThrowingException.java b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/FunctionThrowingException.java index afb9b7df1..8d1b055a7 100644 --- a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/FunctionThrowingException.java +++ b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/FunctionThrowingException.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/ListConst.java b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/ListConst.java index 3efda6b3e..827a302f3 100644 --- a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/ListConst.java +++ b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/ListConst.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/Name.java b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/Name.java index a26945602..3bf6bf8c1 100644 --- a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/Name.java +++ b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/Name.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/ParserException.java b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/ParserException.java index 0b946c475..f0a23913c 100644 --- a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/ParserException.java +++ b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/ParserException.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/Range.java b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/Range.java index aa4c66f7a..1677df737 100644 --- a/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/Range.java +++ b/es6-persistence/src/main/java/com/netflix/conductor/es6/dao/query/parser/internal/Range.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/index/ElasticSearchDaoBaseTest.java b/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/index/ElasticSearchDaoBaseTest.java index 529f22e12..337bb3135 100644 --- a/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/index/ElasticSearchDaoBaseTest.java +++ b/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/index/ElasticSearchDaoBaseTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/index/ElasticSearchRestDaoBaseTest.java b/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/index/ElasticSearchRestDaoBaseTest.java index 59584e1dc..701926be7 100644 --- a/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/index/ElasticSearchRestDaoBaseTest.java +++ b/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/index/ElasticSearchRestDaoBaseTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/index/ElasticSearchTest.java b/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/index/ElasticSearchTest.java index 2cbc2ff86..269157925 100644 --- a/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/index/ElasticSearchTest.java +++ b/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/index/ElasticSearchTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/index/TestElasticSearchDAOV6.java b/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/index/TestElasticSearchDAOV6.java index afb54e8cb..d56326b39 100644 --- a/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/index/TestElasticSearchDAOV6.java +++ b/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/index/TestElasticSearchDAOV6.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/index/TestElasticSearchDAOV6Batch.java b/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/index/TestElasticSearchDAOV6Batch.java index 8a1f14ef9..b8f33be55 100644 --- a/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/index/TestElasticSearchDAOV6Batch.java +++ b/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/index/TestElasticSearchDAOV6Batch.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/index/TestElasticSearchRestDAOV6.java b/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/index/TestElasticSearchRestDAOV6.java index 8a2d6d52c..c8de43025 100644 --- a/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/index/TestElasticSearchRestDAOV6.java +++ b/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/index/TestElasticSearchRestDAOV6.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/index/TestElasticSearchRestDAOV6Batch.java b/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/index/TestElasticSearchRestDAOV6Batch.java index 98f503923..c2b053739 100644 --- a/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/index/TestElasticSearchRestDAOV6Batch.java +++ b/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/index/TestElasticSearchRestDAOV6Batch.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/query/parser/TestExpression.java b/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/query/parser/TestExpression.java index 8ebe4c83f..212773e8f 100644 --- a/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/query/parser/TestExpression.java +++ b/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/query/parser/TestExpression.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/query/parser/internal/TestAbstractParser.java b/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/query/parser/internal/TestAbstractParser.java index 36a2adc48..fe8792b2f 100644 --- a/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/query/parser/internal/TestAbstractParser.java +++ b/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/query/parser/internal/TestAbstractParser.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/query/parser/internal/TestBooleanOp.java b/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/query/parser/internal/TestBooleanOp.java index 216c289a2..308063e9a 100644 --- a/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/query/parser/internal/TestBooleanOp.java +++ b/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/query/parser/internal/TestBooleanOp.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/query/parser/internal/TestComparisonOp.java b/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/query/parser/internal/TestComparisonOp.java index 3878947df..d9a90b18f 100644 --- a/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/query/parser/internal/TestComparisonOp.java +++ b/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/query/parser/internal/TestComparisonOp.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/query/parser/internal/TestConstValue.java b/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/query/parser/internal/TestConstValue.java index 2ae311d54..7d4f04690 100644 --- a/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/query/parser/internal/TestConstValue.java +++ b/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/query/parser/internal/TestConstValue.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/query/parser/internal/TestName.java b/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/query/parser/internal/TestName.java index 3de5abdc0..f5a366360 100644 --- a/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/query/parser/internal/TestName.java +++ b/es6-persistence/src/test/java/com/netflix/conductor/es6/dao/query/parser/internal/TestName.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es6-persistence/src/test/java/com/netflix/conductor/es6/utils/TestUtils.java b/es6-persistence/src/test/java/com/netflix/conductor/es6/utils/TestUtils.java index 4cb8d234d..9f1e822a3 100644 --- a/es6-persistence/src/test/java/com/netflix/conductor/es6/utils/TestUtils.java +++ b/es6-persistence/src/test/java/com/netflix/conductor/es6/utils/TestUtils.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/main/java/com/netflix/conductor/es7/config/ElasticSearchConditions.java b/es7-persistence/src/main/java/com/netflix/conductor/es7/config/ElasticSearchConditions.java index 9875f1776..e36f38dee 100644 --- a/es7-persistence/src/main/java/com/netflix/conductor/es7/config/ElasticSearchConditions.java +++ b/es7-persistence/src/main/java/com/netflix/conductor/es7/config/ElasticSearchConditions.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/main/java/com/netflix/conductor/es7/config/ElasticSearchProperties.java b/es7-persistence/src/main/java/com/netflix/conductor/es7/config/ElasticSearchProperties.java index d4ed352a7..010d17565 100644 --- a/es7-persistence/src/main/java/com/netflix/conductor/es7/config/ElasticSearchProperties.java +++ b/es7-persistence/src/main/java/com/netflix/conductor/es7/config/ElasticSearchProperties.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/main/java/com/netflix/conductor/es7/config/ElasticSearchV7Configuration.java b/es7-persistence/src/main/java/com/netflix/conductor/es7/config/ElasticSearchV7Configuration.java index 3bbdb0fab..4b6e65922 100644 --- a/es7-persistence/src/main/java/com/netflix/conductor/es7/config/ElasticSearchV7Configuration.java +++ b/es7-persistence/src/main/java/com/netflix/conductor/es7/config/ElasticSearchV7Configuration.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/index/BulkRequestBuilderWrapper.java b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/index/BulkRequestBuilderWrapper.java index a41f38568..299402582 100644 --- a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/index/BulkRequestBuilderWrapper.java +++ b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/index/BulkRequestBuilderWrapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/index/BulkRequestWrapper.java b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/index/BulkRequestWrapper.java index 66d3a26b4..65d857cb9 100644 --- a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/index/BulkRequestWrapper.java +++ b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/index/BulkRequestWrapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/index/ElasticSearchBaseDAO.java b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/index/ElasticSearchBaseDAO.java index 6abb4c742..b202a42ab 100644 --- a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/index/ElasticSearchBaseDAO.java +++ b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/index/ElasticSearchBaseDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/index/ElasticSearchRestDAOV7.java b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/index/ElasticSearchRestDAOV7.java index a137fd08d..8af6d8135 100644 --- a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/index/ElasticSearchRestDAOV7.java +++ b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/index/ElasticSearchRestDAOV7.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/Expression.java b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/Expression.java index 7cb3d7f3b..365643f46 100644 --- a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/Expression.java +++ b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/Expression.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/FilterProvider.java b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/FilterProvider.java index f4de4d36b..6c5641457 100644 --- a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/FilterProvider.java +++ b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/FilterProvider.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/GroupedExpression.java b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/GroupedExpression.java index 67aa8965c..051741c65 100644 --- a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/GroupedExpression.java +++ b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/GroupedExpression.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/NameValue.java b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/NameValue.java index b81c9f94b..26b1642b9 100644 --- a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/NameValue.java +++ b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/NameValue.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/AbstractNode.java b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/AbstractNode.java index bfbd3988f..4bb8e73e8 100644 --- a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/AbstractNode.java +++ b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/AbstractNode.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/BooleanOp.java b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/BooleanOp.java index f37c5f200..b630b8a37 100644 --- a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/BooleanOp.java +++ b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/BooleanOp.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/ComparisonOp.java b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/ComparisonOp.java index 55d8d49a8..e54f020f8 100644 --- a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/ComparisonOp.java +++ b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/ComparisonOp.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/ConstValue.java b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/ConstValue.java index edc9513c1..32fa2b117 100644 --- a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/ConstValue.java +++ b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/ConstValue.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/FunctionThrowingException.java b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/FunctionThrowingException.java index 97afc3684..5fece418d 100644 --- a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/FunctionThrowingException.java +++ b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/FunctionThrowingException.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/ListConst.java b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/ListConst.java index 87227a863..aa9394576 100644 --- a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/ListConst.java +++ b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/ListConst.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/Name.java b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/Name.java index 589b62ccd..5c9944528 100644 --- a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/Name.java +++ b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/Name.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/ParserException.java b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/ParserException.java index 08a9d7b08..37f68267c 100644 --- a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/ParserException.java +++ b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/ParserException.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/Range.java b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/Range.java index 6315e00fa..36104de47 100644 --- a/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/Range.java +++ b/es7-persistence/src/main/java/com/netflix/conductor/es7/dao/query/parser/internal/Range.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/index/ElasticSearchRestDaoBaseTest.java b/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/index/ElasticSearchRestDaoBaseTest.java index a209c3ea7..f3389dbfe 100644 --- a/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/index/ElasticSearchRestDaoBaseTest.java +++ b/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/index/ElasticSearchRestDaoBaseTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/index/ElasticSearchTest.java b/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/index/ElasticSearchTest.java index 4004be56f..6183b9182 100644 --- a/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/index/ElasticSearchTest.java +++ b/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/index/ElasticSearchTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/index/TestBulkRequestBuilderWrapper.java b/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/index/TestBulkRequestBuilderWrapper.java index f63110039..2709e3913 100644 --- a/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/index/TestBulkRequestBuilderWrapper.java +++ b/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/index/TestBulkRequestBuilderWrapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/index/TestElasticSearchRestDAOV7.java b/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/index/TestElasticSearchRestDAOV7.java index 2bbb4ed67..4bccf1deb 100644 --- a/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/index/TestElasticSearchRestDAOV7.java +++ b/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/index/TestElasticSearchRestDAOV7.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/index/TestElasticSearchRestDAOV7Batch.java b/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/index/TestElasticSearchRestDAOV7Batch.java index df9ec6e95..373339c8e 100644 --- a/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/index/TestElasticSearchRestDAOV7Batch.java +++ b/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/index/TestElasticSearchRestDAOV7Batch.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/query/parser/TestExpression.java b/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/query/parser/TestExpression.java index 5ca4f0284..b8d580b0c 100644 --- a/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/query/parser/TestExpression.java +++ b/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/query/parser/TestExpression.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/query/parser/TestGroupedExpression.java b/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/query/parser/TestGroupedExpression.java index ed79b0f91..d114ec0e4 100644 --- a/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/query/parser/TestGroupedExpression.java +++ b/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/query/parser/TestGroupedExpression.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/query/parser/internal/AbstractParserTest.java b/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/query/parser/internal/AbstractParserTest.java index 412b7a8a6..91e3583da 100644 --- a/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/query/parser/internal/AbstractParserTest.java +++ b/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/query/parser/internal/AbstractParserTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/query/parser/internal/TestBooleanOp.java b/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/query/parser/internal/TestBooleanOp.java index 6f8c70e11..d2b6f38c5 100644 --- a/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/query/parser/internal/TestBooleanOp.java +++ b/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/query/parser/internal/TestBooleanOp.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/query/parser/internal/TestComparisonOp.java b/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/query/parser/internal/TestComparisonOp.java index 40c615f87..585efd2c5 100644 --- a/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/query/parser/internal/TestComparisonOp.java +++ b/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/query/parser/internal/TestComparisonOp.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/query/parser/internal/TestConstValue.java b/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/query/parser/internal/TestConstValue.java index ee5769990..28871d4ed 100644 --- a/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/query/parser/internal/TestConstValue.java +++ b/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/query/parser/internal/TestConstValue.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/query/parser/internal/TestName.java b/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/query/parser/internal/TestName.java index 26a192301..b7d2a7a4a 100644 --- a/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/query/parser/internal/TestName.java +++ b/es7-persistence/src/test/java/com/netflix/conductor/es7/dao/query/parser/internal/TestName.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/es7-persistence/src/test/java/com/netflix/conductor/es7/utils/TestUtils.java b/es7-persistence/src/test/java/com/netflix/conductor/es7/utils/TestUtils.java index 5889cccd4..729336ed5 100644 --- a/es7-persistence/src/test/java/com/netflix/conductor/es7/utils/TestUtils.java +++ b/es7-persistence/src/test/java/com/netflix/conductor/es7/utils/TestUtils.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/grpc-client/src/main/java/com/netflix/conductor/client/grpc/ClientBase.java b/grpc-client/src/main/java/com/netflix/conductor/client/grpc/ClientBase.java index 0450547c5..90b61128c 100644 --- a/grpc-client/src/main/java/com/netflix/conductor/client/grpc/ClientBase.java +++ b/grpc-client/src/main/java/com/netflix/conductor/client/grpc/ClientBase.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/grpc-client/src/main/java/com/netflix/conductor/client/grpc/EventClient.java b/grpc-client/src/main/java/com/netflix/conductor/client/grpc/EventClient.java index a781bc186..5f11ba94b 100644 --- a/grpc-client/src/main/java/com/netflix/conductor/client/grpc/EventClient.java +++ b/grpc-client/src/main/java/com/netflix/conductor/client/grpc/EventClient.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/grpc-client/src/main/java/com/netflix/conductor/client/grpc/MetadataClient.java b/grpc-client/src/main/java/com/netflix/conductor/client/grpc/MetadataClient.java index 83e51cd64..f05f5ca8f 100644 --- a/grpc-client/src/main/java/com/netflix/conductor/client/grpc/MetadataClient.java +++ b/grpc-client/src/main/java/com/netflix/conductor/client/grpc/MetadataClient.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/grpc-client/src/main/java/com/netflix/conductor/client/grpc/TaskClient.java b/grpc-client/src/main/java/com/netflix/conductor/client/grpc/TaskClient.java index 0cbf37c99..6004db595 100644 --- a/grpc-client/src/main/java/com/netflix/conductor/client/grpc/TaskClient.java +++ b/grpc-client/src/main/java/com/netflix/conductor/client/grpc/TaskClient.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/grpc-client/src/main/java/com/netflix/conductor/client/grpc/WorkflowClient.java b/grpc-client/src/main/java/com/netflix/conductor/client/grpc/WorkflowClient.java index 86c78e682..557ace652 100644 --- a/grpc-client/src/main/java/com/netflix/conductor/client/grpc/WorkflowClient.java +++ b/grpc-client/src/main/java/com/netflix/conductor/client/grpc/WorkflowClient.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/grpc-client/src/test/java/com/netflix/conductor/client/grpc/EventClientTest.java b/grpc-client/src/test/java/com/netflix/conductor/client/grpc/EventClientTest.java index 70a22c8f9..44b890685 100644 --- a/grpc-client/src/test/java/com/netflix/conductor/client/grpc/EventClientTest.java +++ b/grpc-client/src/test/java/com/netflix/conductor/client/grpc/EventClientTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/grpc-client/src/test/java/com/netflix/conductor/client/grpc/TaskClientTest.java b/grpc-client/src/test/java/com/netflix/conductor/client/grpc/TaskClientTest.java index d55bd7b67..367318abe 100644 --- a/grpc-client/src/test/java/com/netflix/conductor/client/grpc/TaskClientTest.java +++ b/grpc-client/src/test/java/com/netflix/conductor/client/grpc/TaskClientTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/grpc-client/src/test/java/com/netflix/conductor/client/grpc/WorkflowClientTest.java b/grpc-client/src/test/java/com/netflix/conductor/client/grpc/WorkflowClientTest.java index fe187f21d..289c526c9 100644 --- a/grpc-client/src/test/java/com/netflix/conductor/client/grpc/WorkflowClientTest.java +++ b/grpc-client/src/test/java/com/netflix/conductor/client/grpc/WorkflowClientTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/grpc-server/src/main/java/com/netflix/conductor/grpc/server/GRPCServer.java b/grpc-server/src/main/java/com/netflix/conductor/grpc/server/GRPCServer.java index 4f62be3d8..e599f8fb0 100644 --- a/grpc-server/src/main/java/com/netflix/conductor/grpc/server/GRPCServer.java +++ b/grpc-server/src/main/java/com/netflix/conductor/grpc/server/GRPCServer.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/grpc-server/src/main/java/com/netflix/conductor/grpc/server/GRPCServerProperties.java b/grpc-server/src/main/java/com/netflix/conductor/grpc/server/GRPCServerProperties.java index 3b88e2056..ad4dc646c 100644 --- a/grpc-server/src/main/java/com/netflix/conductor/grpc/server/GRPCServerProperties.java +++ b/grpc-server/src/main/java/com/netflix/conductor/grpc/server/GRPCServerProperties.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/grpc-server/src/main/java/com/netflix/conductor/grpc/server/GrpcConfiguration.java b/grpc-server/src/main/java/com/netflix/conductor/grpc/server/GrpcConfiguration.java index dee9bfdcb..77be5a974 100644 --- a/grpc-server/src/main/java/com/netflix/conductor/grpc/server/GrpcConfiguration.java +++ b/grpc-server/src/main/java/com/netflix/conductor/grpc/server/GrpcConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/grpc-server/src/main/java/com/netflix/conductor/grpc/server/service/EventServiceImpl.java b/grpc-server/src/main/java/com/netflix/conductor/grpc/server/service/EventServiceImpl.java index 229af7d27..497454796 100644 --- a/grpc-server/src/main/java/com/netflix/conductor/grpc/server/service/EventServiceImpl.java +++ b/grpc-server/src/main/java/com/netflix/conductor/grpc/server/service/EventServiceImpl.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/grpc-server/src/main/java/com/netflix/conductor/grpc/server/service/GRPCHelper.java b/grpc-server/src/main/java/com/netflix/conductor/grpc/server/service/GRPCHelper.java index 4b0cae8bb..95a910243 100644 --- a/grpc-server/src/main/java/com/netflix/conductor/grpc/server/service/GRPCHelper.java +++ b/grpc-server/src/main/java/com/netflix/conductor/grpc/server/service/GRPCHelper.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/grpc-server/src/main/java/com/netflix/conductor/grpc/server/service/HealthServiceImpl.java b/grpc-server/src/main/java/com/netflix/conductor/grpc/server/service/HealthServiceImpl.java index 6bd26d2de..e2e947e1d 100644 --- a/grpc-server/src/main/java/com/netflix/conductor/grpc/server/service/HealthServiceImpl.java +++ b/grpc-server/src/main/java/com/netflix/conductor/grpc/server/service/HealthServiceImpl.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/grpc-server/src/main/java/com/netflix/conductor/grpc/server/service/MetadataServiceImpl.java b/grpc-server/src/main/java/com/netflix/conductor/grpc/server/service/MetadataServiceImpl.java index 369430d68..9aad0b974 100644 --- a/grpc-server/src/main/java/com/netflix/conductor/grpc/server/service/MetadataServiceImpl.java +++ b/grpc-server/src/main/java/com/netflix/conductor/grpc/server/service/MetadataServiceImpl.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/grpc-server/src/main/java/com/netflix/conductor/grpc/server/service/TaskServiceImpl.java b/grpc-server/src/main/java/com/netflix/conductor/grpc/server/service/TaskServiceImpl.java index aaee4ac1b..33bc7560a 100644 --- a/grpc-server/src/main/java/com/netflix/conductor/grpc/server/service/TaskServiceImpl.java +++ b/grpc-server/src/main/java/com/netflix/conductor/grpc/server/service/TaskServiceImpl.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/grpc-server/src/main/java/com/netflix/conductor/grpc/server/service/WorkflowServiceImpl.java b/grpc-server/src/main/java/com/netflix/conductor/grpc/server/service/WorkflowServiceImpl.java index 3b10b3310..df60fb662 100644 --- a/grpc-server/src/main/java/com/netflix/conductor/grpc/server/service/WorkflowServiceImpl.java +++ b/grpc-server/src/main/java/com/netflix/conductor/grpc/server/service/WorkflowServiceImpl.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/grpc-server/src/test/java/com/netflix/conductor/grpc/server/service/HealthServiceImplTest.java b/grpc-server/src/test/java/com/netflix/conductor/grpc/server/service/HealthServiceImplTest.java index 88967b17f..905a98c80 100644 --- a/grpc-server/src/test/java/com/netflix/conductor/grpc/server/service/HealthServiceImplTest.java +++ b/grpc-server/src/test/java/com/netflix/conductor/grpc/server/service/HealthServiceImplTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/grpc-server/src/test/java/com/netflix/conductor/grpc/server/service/TaskServiceImplTest.java b/grpc-server/src/test/java/com/netflix/conductor/grpc/server/service/TaskServiceImplTest.java index e5e7aa4eb..1bfd8256f 100644 --- a/grpc-server/src/test/java/com/netflix/conductor/grpc/server/service/TaskServiceImplTest.java +++ b/grpc-server/src/test/java/com/netflix/conductor/grpc/server/service/TaskServiceImplTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/grpc-server/src/test/java/com/netflix/conductor/grpc/server/service/WorkflowServiceImplTest.java b/grpc-server/src/test/java/com/netflix/conductor/grpc/server/service/WorkflowServiceImplTest.java index 17417d029..6be23634b 100644 --- a/grpc-server/src/test/java/com/netflix/conductor/grpc/server/service/WorkflowServiceImplTest.java +++ b/grpc-server/src/test/java/com/netflix/conductor/grpc/server/service/WorkflowServiceImplTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/http-task/src/main/java/com/netflix/conductor/tasks/http/HttpTask.java b/http-task/src/main/java/com/netflix/conductor/tasks/http/HttpTask.java index d388b165e..d85fa2484 100644 --- a/http-task/src/main/java/com/netflix/conductor/tasks/http/HttpTask.java +++ b/http-task/src/main/java/com/netflix/conductor/tasks/http/HttpTask.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/http-task/src/main/java/com/netflix/conductor/tasks/http/providers/DefaultRestTemplateProvider.java b/http-task/src/main/java/com/netflix/conductor/tasks/http/providers/DefaultRestTemplateProvider.java index 0a1cfd2f7..0efae0591 100644 --- a/http-task/src/main/java/com/netflix/conductor/tasks/http/providers/DefaultRestTemplateProvider.java +++ b/http-task/src/main/java/com/netflix/conductor/tasks/http/providers/DefaultRestTemplateProvider.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/http-task/src/main/java/com/netflix/conductor/tasks/http/providers/RestTemplateProvider.java b/http-task/src/main/java/com/netflix/conductor/tasks/http/providers/RestTemplateProvider.java index 968904d2e..6744c0b66 100644 --- a/http-task/src/main/java/com/netflix/conductor/tasks/http/providers/RestTemplateProvider.java +++ b/http-task/src/main/java/com/netflix/conductor/tasks/http/providers/RestTemplateProvider.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/http-task/src/test/java/com/netflix/conductor/tasks/http/HttpTaskTest.java b/http-task/src/test/java/com/netflix/conductor/tasks/http/HttpTaskTest.java index 2b2f6a6df..5a26fd59a 100644 --- a/http-task/src/test/java/com/netflix/conductor/tasks/http/HttpTaskTest.java +++ b/http-task/src/test/java/com/netflix/conductor/tasks/http/HttpTaskTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/http-task/src/test/java/com/netflix/conductor/tasks/http/providers/DefaultRestTemplateProviderTest.java b/http-task/src/test/java/com/netflix/conductor/tasks/http/providers/DefaultRestTemplateProviderTest.java index 3141e47e5..7dba45210 100644 --- a/http-task/src/test/java/com/netflix/conductor/tasks/http/providers/DefaultRestTemplateProviderTest.java +++ b/http-task/src/test/java/com/netflix/conductor/tasks/http/providers/DefaultRestTemplateProviderTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/example/java/com/netflix/conductor/sdk/example/shipment/Order.java b/java-sdk/example/java/com/netflix/conductor/sdk/example/shipment/Order.java index 2258c2918..7d8a4829f 100644 --- a/java-sdk/example/java/com/netflix/conductor/sdk/example/shipment/Order.java +++ b/java-sdk/example/java/com/netflix/conductor/sdk/example/shipment/Order.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/example/java/com/netflix/conductor/sdk/example/shipment/Shipment.java b/java-sdk/example/java/com/netflix/conductor/sdk/example/shipment/Shipment.java index f5f32d6a4..ba621a564 100644 --- a/java-sdk/example/java/com/netflix/conductor/sdk/example/shipment/Shipment.java +++ b/java-sdk/example/java/com/netflix/conductor/sdk/example/shipment/Shipment.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/example/java/com/netflix/conductor/sdk/example/shipment/ShipmentState.java b/java-sdk/example/java/com/netflix/conductor/sdk/example/shipment/ShipmentState.java index c0abd12df..d71f58436 100644 --- a/java-sdk/example/java/com/netflix/conductor/sdk/example/shipment/ShipmentState.java +++ b/java-sdk/example/java/com/netflix/conductor/sdk/example/shipment/ShipmentState.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/example/java/com/netflix/conductor/sdk/example/shipment/ShipmentWorkers.java b/java-sdk/example/java/com/netflix/conductor/sdk/example/shipment/ShipmentWorkers.java index 95d927b11..9698f1e08 100644 --- a/java-sdk/example/java/com/netflix/conductor/sdk/example/shipment/ShipmentWorkers.java +++ b/java-sdk/example/java/com/netflix/conductor/sdk/example/shipment/ShipmentWorkers.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/example/java/com/netflix/conductor/sdk/example/shipment/ShipmentWorkflow.java b/java-sdk/example/java/com/netflix/conductor/sdk/example/shipment/ShipmentWorkflow.java index c22ba662a..809dec6b3 100644 --- a/java-sdk/example/java/com/netflix/conductor/sdk/example/shipment/ShipmentWorkflow.java +++ b/java-sdk/example/java/com/netflix/conductor/sdk/example/shipment/ShipmentWorkflow.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/example/java/com/netflix/conductor/sdk/example/shipment/User.java b/java-sdk/example/java/com/netflix/conductor/sdk/example/shipment/User.java index e5a5233d2..0c8324a93 100644 --- a/java-sdk/example/java/com/netflix/conductor/sdk/example/shipment/User.java +++ b/java-sdk/example/java/com/netflix/conductor/sdk/example/shipment/User.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/healthcheck/HealthCheckClient.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/healthcheck/HealthCheckClient.java index e8a83b30a..014ab1d80 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/healthcheck/HealthCheckClient.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/healthcheck/HealthCheckClient.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/testing/LocalServerRunner.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/testing/LocalServerRunner.java index 452336431..0d60c9f4d 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/testing/LocalServerRunner.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/testing/LocalServerRunner.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/testing/WorkflowTestRunner.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/testing/WorkflowTestRunner.java index 758445c03..398d5c29f 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/testing/WorkflowTestRunner.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/testing/WorkflowTestRunner.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/ConductorWorkflow.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/ConductorWorkflow.java index 009aa517a..d3bc031ca 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/ConductorWorkflow.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/ConductorWorkflow.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/ValidationError.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/ValidationError.java index 761835955..f795ab5f9 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/ValidationError.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/ValidationError.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/WorkflowBuilder.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/WorkflowBuilder.java index caf33d8cf..2e90f7aa6 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/WorkflowBuilder.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/WorkflowBuilder.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/DoWhile.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/DoWhile.java index 20634179e..6d616542e 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/DoWhile.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/DoWhile.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Dynamic.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Dynamic.java index ae1bb0777..9ad9b3593 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Dynamic.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Dynamic.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/DynamicFork.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/DynamicFork.java index f5d2c11ab..e3ae4f182 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/DynamicFork.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/DynamicFork.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/DynamicForkInput.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/DynamicForkInput.java index 7133e0ac3..d715f82f9 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/DynamicForkInput.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/DynamicForkInput.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Event.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Event.java index 26a55fab7..4911a635d 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Event.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Event.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/ForkJoin.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/ForkJoin.java index 69af0ddcb..239c935ac 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/ForkJoin.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/ForkJoin.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Http.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Http.java index b1685d395..06c4ff9fa 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Http.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Http.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/JQ.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/JQ.java index d1eff0580..9121d539d 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/JQ.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/JQ.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Javascript.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Javascript.java index cca0246f7..7260a0586 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Javascript.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Javascript.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Join.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Join.java index f60777aa2..2996d8582 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Join.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Join.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/SetVariable.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/SetVariable.java index d4863dec2..c4260154a 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/SetVariable.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/SetVariable.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/SimpleTask.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/SimpleTask.java index 369aa60f5..7cea277c3 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/SimpleTask.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/SimpleTask.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/SubWorkflow.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/SubWorkflow.java index 2e54be19f..3707cfba5 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/SubWorkflow.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/SubWorkflow.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Switch.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Switch.java index f0f34b2db..bcff758ff 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Switch.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Switch.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Task.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Task.java index eff1f8bdd..28618f234 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Task.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Task.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/TaskRegistry.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/TaskRegistry.java index f0f964330..2a404a7cc 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/TaskRegistry.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/TaskRegistry.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Terminate.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Terminate.java index 01ca245fa..fb7b3d0fd 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Terminate.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Terminate.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Wait.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Wait.java index 1d15592b4..c6f11ef01 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Wait.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/def/tasks/Wait.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/executor/WorkflowExecutor.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/executor/WorkflowExecutor.java index ae75b6c83..15ba64683 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/executor/WorkflowExecutor.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/executor/WorkflowExecutor.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/executor/task/AnnotatedWorker.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/executor/task/AnnotatedWorker.java index d05e34b0a..51b8abcff 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/executor/task/AnnotatedWorker.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/executor/task/AnnotatedWorker.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/executor/task/AnnotatedWorkerExecutor.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/executor/task/AnnotatedWorkerExecutor.java index 411609864..56c06003b 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/executor/task/AnnotatedWorkerExecutor.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/executor/task/AnnotatedWorkerExecutor.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/executor/task/DynamicForkWorker.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/executor/task/DynamicForkWorker.java index 17b8309de..0ba1d6114 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/executor/task/DynamicForkWorker.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/executor/task/DynamicForkWorker.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/executor/task/NonRetryableException.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/executor/task/NonRetryableException.java index 850f1171d..61b70fdc7 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/executor/task/NonRetryableException.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/executor/task/NonRetryableException.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/executor/task/TaskContext.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/executor/task/TaskContext.java index c03ac2f72..f78d13e50 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/executor/task/TaskContext.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/executor/task/TaskContext.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/executor/task/WorkerConfiguration.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/executor/task/WorkerConfiguration.java index 61e01c0a0..45a615773 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/executor/task/WorkerConfiguration.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/executor/task/WorkerConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/task/InputParam.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/task/InputParam.java index d27fa8b7c..2afa8bc42 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/task/InputParam.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/task/InputParam.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/task/OutputParam.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/task/OutputParam.java index a8c6ec378..3c1251317 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/task/OutputParam.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/task/OutputParam.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/task/WorkerTask.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/task/WorkerTask.java index 409b8e74f..f60783124 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/task/WorkerTask.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/task/WorkerTask.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/utils/InputOutputGetter.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/utils/InputOutputGetter.java index 41095b1a2..4e8e34832 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/utils/InputOutputGetter.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/utils/InputOutputGetter.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/utils/MapBuilder.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/utils/MapBuilder.java index 2552d12b5..3882324b4 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/utils/MapBuilder.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/utils/MapBuilder.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/utils/ObjectMapperProvider.java b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/utils/ObjectMapperProvider.java index 4230cac71..1721c8236 100644 --- a/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/utils/ObjectMapperProvider.java +++ b/java-sdk/src/main/java/com/netflix/conductor/sdk/workflow/utils/ObjectMapperProvider.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/def/TaskConversionsTests.java b/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/def/TaskConversionsTests.java index 61cef6a81..9804f1a43 100644 --- a/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/def/TaskConversionsTests.java +++ b/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/def/TaskConversionsTests.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/def/WorkflowCreationTests.java b/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/def/WorkflowCreationTests.java index 194928a9a..90822697f 100644 --- a/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/def/WorkflowCreationTests.java +++ b/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/def/WorkflowCreationTests.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/def/WorkflowDefTaskTests.java b/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/def/WorkflowDefTaskTests.java index a7e818071..31218f129 100644 --- a/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/def/WorkflowDefTaskTests.java +++ b/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/def/WorkflowDefTaskTests.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/def/WorkflowState.java b/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/def/WorkflowState.java index 066d74dbf..05dce8080 100644 --- a/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/def/WorkflowState.java +++ b/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/def/WorkflowState.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/executor/task/AnnotatedWorkerTests.java b/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/executor/task/AnnotatedWorkerTests.java index 3566c49dc..84111ebb0 100644 --- a/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/executor/task/AnnotatedWorkerTests.java +++ b/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/executor/task/AnnotatedWorkerTests.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/executor/task/TestWorkerConfig.java b/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/executor/task/TestWorkerConfig.java index fa77df6b8..93ebd6989 100644 --- a/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/executor/task/TestWorkerConfig.java +++ b/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/executor/task/TestWorkerConfig.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/testing/Task1Input.java b/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/testing/Task1Input.java index 3cb3375da..0f7996e00 100644 --- a/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/testing/Task1Input.java +++ b/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/testing/Task1Input.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/testing/TestWorkflowInput.java b/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/testing/TestWorkflowInput.java index 3caa0d1df..62716e161 100644 --- a/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/testing/TestWorkflowInput.java +++ b/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/testing/TestWorkflowInput.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/testing/WorkflowTestFrameworkTests.java b/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/testing/WorkflowTestFrameworkTests.java index d691b5d9a..4518ea83c 100644 --- a/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/testing/WorkflowTestFrameworkTests.java +++ b/java-sdk/src/test/java/com/netflix/conductor/sdk/workflow/testing/WorkflowTestFrameworkTests.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/json-jq-task/src/main/java/com/netflix/conductor/tasks/json/JsonJqTransform.java b/json-jq-task/src/main/java/com/netflix/conductor/tasks/json/JsonJqTransform.java index 0cbed1c5d..583b2f492 100644 --- a/json-jq-task/src/main/java/com/netflix/conductor/tasks/json/JsonJqTransform.java +++ b/json-jq-task/src/main/java/com/netflix/conductor/tasks/json/JsonJqTransform.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/json-jq-task/src/test/java/com/netflix/conductor/tasks/json/JsonJqTransformTest.java b/json-jq-task/src/test/java/com/netflix/conductor/tasks/json/JsonJqTransformTest.java index 815993f77..73f9fd9a2 100644 --- a/json-jq-task/src/test/java/com/netflix/conductor/tasks/json/JsonJqTransformTest.java +++ b/json-jq-task/src/test/java/com/netflix/conductor/tasks/json/JsonJqTransformTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/kafka/src/main/java/com/netflix/conductor/contribs/tasks/kafka/KafkaProducerManager.java b/kafka/src/main/java/com/netflix/conductor/contribs/tasks/kafka/KafkaProducerManager.java index af6100b2a..013f83ed9 100644 --- a/kafka/src/main/java/com/netflix/conductor/contribs/tasks/kafka/KafkaProducerManager.java +++ b/kafka/src/main/java/com/netflix/conductor/contribs/tasks/kafka/KafkaProducerManager.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/kafka/src/main/java/com/netflix/conductor/contribs/tasks/kafka/KafkaPublishTask.java b/kafka/src/main/java/com/netflix/conductor/contribs/tasks/kafka/KafkaPublishTask.java index 870a8903a..0a7377d8e 100644 --- a/kafka/src/main/java/com/netflix/conductor/contribs/tasks/kafka/KafkaPublishTask.java +++ b/kafka/src/main/java/com/netflix/conductor/contribs/tasks/kafka/KafkaPublishTask.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/kafka/src/main/java/com/netflix/conductor/core/execution/mapper/KafkaPublishTaskMapper.java b/kafka/src/main/java/com/netflix/conductor/core/execution/mapper/KafkaPublishTaskMapper.java index 98bfacb5f..f9926e459 100644 --- a/kafka/src/main/java/com/netflix/conductor/core/execution/mapper/KafkaPublishTaskMapper.java +++ b/kafka/src/main/java/com/netflix/conductor/core/execution/mapper/KafkaPublishTaskMapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/kafka/src/test/java/com/netflix/conductor/contribs/tasks/kafka/KafkaProducerManagerTest.java b/kafka/src/test/java/com/netflix/conductor/contribs/tasks/kafka/KafkaProducerManagerTest.java index 91fef3029..eea69fdc3 100644 --- a/kafka/src/test/java/com/netflix/conductor/contribs/tasks/kafka/KafkaProducerManagerTest.java +++ b/kafka/src/test/java/com/netflix/conductor/contribs/tasks/kafka/KafkaProducerManagerTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/kafka/src/test/java/com/netflix/conductor/contribs/tasks/kafka/KafkaPublishTaskTest.java b/kafka/src/test/java/com/netflix/conductor/contribs/tasks/kafka/KafkaPublishTaskTest.java index 08828c444..b1360c4e3 100644 --- a/kafka/src/test/java/com/netflix/conductor/contribs/tasks/kafka/KafkaPublishTaskTest.java +++ b/kafka/src/test/java/com/netflix/conductor/contribs/tasks/kafka/KafkaPublishTaskTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/kafka/src/test/java/com/netflix/conductor/core/execution/mapper/KafkaPublishTaskMapperTest.java b/kafka/src/test/java/com/netflix/conductor/core/execution/mapper/KafkaPublishTaskMapperTest.java index 471bde2ff..1be8e89c1 100644 --- a/kafka/src/test/java/com/netflix/conductor/core/execution/mapper/KafkaPublishTaskMapperTest.java +++ b/kafka/src/test/java/com/netflix/conductor/core/execution/mapper/KafkaPublishTaskMapperTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/licenseheader.txt b/licenseheader.txt index 0edfbaf25..03879c60c 100644 --- a/licenseheader.txt +++ b/licenseheader.txt @@ -1,5 +1,5 @@ /* - * Copyright $YEAR Netflix, Inc. + * Copyright $YEAR Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/metrics/src/main/java/com/netflix/conductor/contribs/metrics/LoggingMetricsConfiguration.java b/metrics/src/main/java/com/netflix/conductor/contribs/metrics/LoggingMetricsConfiguration.java index fb71cbc31..581028981 100644 --- a/metrics/src/main/java/com/netflix/conductor/contribs/metrics/LoggingMetricsConfiguration.java +++ b/metrics/src/main/java/com/netflix/conductor/contribs/metrics/LoggingMetricsConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/metrics/src/main/java/com/netflix/conductor/contribs/metrics/MetricsRegistryConfiguration.java b/metrics/src/main/java/com/netflix/conductor/contribs/metrics/MetricsRegistryConfiguration.java index 9b53ed523..9b52b24e8 100644 --- a/metrics/src/main/java/com/netflix/conductor/contribs/metrics/MetricsRegistryConfiguration.java +++ b/metrics/src/main/java/com/netflix/conductor/contribs/metrics/MetricsRegistryConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/metrics/src/main/java/com/netflix/conductor/contribs/metrics/PrometheusMetricsConfiguration.java b/metrics/src/main/java/com/netflix/conductor/contribs/metrics/PrometheusMetricsConfiguration.java index a610f7978..38c5756c7 100644 --- a/metrics/src/main/java/com/netflix/conductor/contribs/metrics/PrometheusMetricsConfiguration.java +++ b/metrics/src/main/java/com/netflix/conductor/contribs/metrics/PrometheusMetricsConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/metrics/src/test/java/com/netflix/conductor/contribs/metrics/LoggingMetricsConfigurationTest.java b/metrics/src/test/java/com/netflix/conductor/contribs/metrics/LoggingMetricsConfigurationTest.java index 333af5f4f..20e84f6fc 100644 --- a/metrics/src/test/java/com/netflix/conductor/contribs/metrics/LoggingMetricsConfigurationTest.java +++ b/metrics/src/test/java/com/netflix/conductor/contribs/metrics/LoggingMetricsConfigurationTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/metrics/src/test/java/com/netflix/conductor/contribs/metrics/PrometheusMetricsConfigurationTest.java b/metrics/src/test/java/com/netflix/conductor/contribs/metrics/PrometheusMetricsConfigurationTest.java index 0a7324ada..f094d377b 100644 --- a/metrics/src/test/java/com/netflix/conductor/contribs/metrics/PrometheusMetricsConfigurationTest.java +++ b/metrics/src/test/java/com/netflix/conductor/contribs/metrics/PrometheusMetricsConfigurationTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/mysql-persistence/src/main/java/com/netflix/conductor/mysql/config/MySQLConfiguration.java b/mysql-persistence/src/main/java/com/netflix/conductor/mysql/config/MySQLConfiguration.java index fe5cf9795..22c407892 100644 --- a/mysql-persistence/src/main/java/com/netflix/conductor/mysql/config/MySQLConfiguration.java +++ b/mysql-persistence/src/main/java/com/netflix/conductor/mysql/config/MySQLConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/mysql-persistence/src/main/java/com/netflix/conductor/mysql/config/MySQLProperties.java b/mysql-persistence/src/main/java/com/netflix/conductor/mysql/config/MySQLProperties.java index 7c926114b..d6fd7e5e0 100644 --- a/mysql-persistence/src/main/java/com/netflix/conductor/mysql/config/MySQLProperties.java +++ b/mysql-persistence/src/main/java/com/netflix/conductor/mysql/config/MySQLProperties.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/mysql-persistence/src/main/java/com/netflix/conductor/mysql/dao/MySQLBaseDAO.java b/mysql-persistence/src/main/java/com/netflix/conductor/mysql/dao/MySQLBaseDAO.java index 2e6f76249..d12dfc52d 100644 --- a/mysql-persistence/src/main/java/com/netflix/conductor/mysql/dao/MySQLBaseDAO.java +++ b/mysql-persistence/src/main/java/com/netflix/conductor/mysql/dao/MySQLBaseDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/mysql-persistence/src/main/java/com/netflix/conductor/mysql/dao/MySQLExecutionDAO.java b/mysql-persistence/src/main/java/com/netflix/conductor/mysql/dao/MySQLExecutionDAO.java index 17731add1..04939469d 100644 --- a/mysql-persistence/src/main/java/com/netflix/conductor/mysql/dao/MySQLExecutionDAO.java +++ b/mysql-persistence/src/main/java/com/netflix/conductor/mysql/dao/MySQLExecutionDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/mysql-persistence/src/main/java/com/netflix/conductor/mysql/dao/MySQLMetadataDAO.java b/mysql-persistence/src/main/java/com/netflix/conductor/mysql/dao/MySQLMetadataDAO.java index 10d543860..badfa51c4 100644 --- a/mysql-persistence/src/main/java/com/netflix/conductor/mysql/dao/MySQLMetadataDAO.java +++ b/mysql-persistence/src/main/java/com/netflix/conductor/mysql/dao/MySQLMetadataDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/mysql-persistence/src/main/java/com/netflix/conductor/mysql/dao/MySQLQueueDAO.java b/mysql-persistence/src/main/java/com/netflix/conductor/mysql/dao/MySQLQueueDAO.java index d84b0e310..d33f3134b 100644 --- a/mysql-persistence/src/main/java/com/netflix/conductor/mysql/dao/MySQLQueueDAO.java +++ b/mysql-persistence/src/main/java/com/netflix/conductor/mysql/dao/MySQLQueueDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/mysql-persistence/src/main/java/com/netflix/conductor/mysql/util/ExecuteFunction.java b/mysql-persistence/src/main/java/com/netflix/conductor/mysql/util/ExecuteFunction.java index 668a8fa61..91a4138aa 100644 --- a/mysql-persistence/src/main/java/com/netflix/conductor/mysql/util/ExecuteFunction.java +++ b/mysql-persistence/src/main/java/com/netflix/conductor/mysql/util/ExecuteFunction.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/mysql-persistence/src/main/java/com/netflix/conductor/mysql/util/LazyToString.java b/mysql-persistence/src/main/java/com/netflix/conductor/mysql/util/LazyToString.java index da45247eb..5f39db411 100644 --- a/mysql-persistence/src/main/java/com/netflix/conductor/mysql/util/LazyToString.java +++ b/mysql-persistence/src/main/java/com/netflix/conductor/mysql/util/LazyToString.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/mysql-persistence/src/main/java/com/netflix/conductor/mysql/util/Query.java b/mysql-persistence/src/main/java/com/netflix/conductor/mysql/util/Query.java index aefa2024f..5dd0a8731 100644 --- a/mysql-persistence/src/main/java/com/netflix/conductor/mysql/util/Query.java +++ b/mysql-persistence/src/main/java/com/netflix/conductor/mysql/util/Query.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/mysql-persistence/src/main/java/com/netflix/conductor/mysql/util/QueryFunction.java b/mysql-persistence/src/main/java/com/netflix/conductor/mysql/util/QueryFunction.java index 5dde942cf..a76c73027 100644 --- a/mysql-persistence/src/main/java/com/netflix/conductor/mysql/util/QueryFunction.java +++ b/mysql-persistence/src/main/java/com/netflix/conductor/mysql/util/QueryFunction.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/mysql-persistence/src/main/java/com/netflix/conductor/mysql/util/ResultSetHandler.java b/mysql-persistence/src/main/java/com/netflix/conductor/mysql/util/ResultSetHandler.java index a21c2ede4..65c0e4860 100644 --- a/mysql-persistence/src/main/java/com/netflix/conductor/mysql/util/ResultSetHandler.java +++ b/mysql-persistence/src/main/java/com/netflix/conductor/mysql/util/ResultSetHandler.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/mysql-persistence/src/main/java/com/netflix/conductor/mysql/util/TransactionalFunction.java b/mysql-persistence/src/main/java/com/netflix/conductor/mysql/util/TransactionalFunction.java index 2e8978e7c..5aa430f87 100644 --- a/mysql-persistence/src/main/java/com/netflix/conductor/mysql/util/TransactionalFunction.java +++ b/mysql-persistence/src/main/java/com/netflix/conductor/mysql/util/TransactionalFunction.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/mysql-persistence/src/test/java/com/netflix/conductor/mysql/dao/MySQLExecutionDAOTest.java b/mysql-persistence/src/test/java/com/netflix/conductor/mysql/dao/MySQLExecutionDAOTest.java index 13908e342..05790c805 100644 --- a/mysql-persistence/src/test/java/com/netflix/conductor/mysql/dao/MySQLExecutionDAOTest.java +++ b/mysql-persistence/src/test/java/com/netflix/conductor/mysql/dao/MySQLExecutionDAOTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/mysql-persistence/src/test/java/com/netflix/conductor/mysql/dao/MySQLMetadataDAOTest.java b/mysql-persistence/src/test/java/com/netflix/conductor/mysql/dao/MySQLMetadataDAOTest.java index d61f972b7..d683f8b04 100644 --- a/mysql-persistence/src/test/java/com/netflix/conductor/mysql/dao/MySQLMetadataDAOTest.java +++ b/mysql-persistence/src/test/java/com/netflix/conductor/mysql/dao/MySQLMetadataDAOTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/mysql-persistence/src/test/java/com/netflix/conductor/mysql/dao/MySQLQueueDAOTest.java b/mysql-persistence/src/test/java/com/netflix/conductor/mysql/dao/MySQLQueueDAOTest.java index 09d1363b1..931185a57 100644 --- a/mysql-persistence/src/test/java/com/netflix/conductor/mysql/dao/MySQLQueueDAOTest.java +++ b/mysql-persistence/src/test/java/com/netflix/conductor/mysql/dao/MySQLQueueDAOTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/mysql-persistence/src/test/java/com/netflix/conductor/test/integration/grpc/mysql/MySQLGrpcEndToEndTest.java b/mysql-persistence/src/test/java/com/netflix/conductor/test/integration/grpc/mysql/MySQLGrpcEndToEndTest.java index d1e4715c6..680623f43 100644 --- a/mysql-persistence/src/test/java/com/netflix/conductor/test/integration/grpc/mysql/MySQLGrpcEndToEndTest.java +++ b/mysql-persistence/src/test/java/com/netflix/conductor/test/integration/grpc/mysql/MySQLGrpcEndToEndTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/NATSAbstractQueue.java b/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/NATSAbstractQueue.java index 738197cb5..907a072a6 100644 --- a/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/NATSAbstractQueue.java +++ b/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/NATSAbstractQueue.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/NATSObservableQueue.java b/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/NATSObservableQueue.java index e2d758157..de941c15c 100644 --- a/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/NATSObservableQueue.java +++ b/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/NATSObservableQueue.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/NATSStreamObservableQueue.java b/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/NATSStreamObservableQueue.java index 5f3c17e68..c150e27d5 100644 --- a/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/NATSStreamObservableQueue.java +++ b/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/NATSStreamObservableQueue.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/config/NATSConfiguration.java b/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/config/NATSConfiguration.java index 2b1b8a767..3b9e25bd2 100644 --- a/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/config/NATSConfiguration.java +++ b/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/config/NATSConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/config/NATSEventQueueProvider.java b/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/config/NATSEventQueueProvider.java index 0bee790d4..48f29df34 100644 --- a/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/config/NATSEventQueueProvider.java +++ b/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/config/NATSEventQueueProvider.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/config/NATSStreamConfiguration.java b/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/config/NATSStreamConfiguration.java index 492da53a4..325293d1f 100644 --- a/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/config/NATSStreamConfiguration.java +++ b/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/config/NATSStreamConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/config/NATSStreamEventQueueProvider.java b/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/config/NATSStreamEventQueueProvider.java index 29de21e7b..6d131dc20 100644 --- a/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/config/NATSStreamEventQueueProvider.java +++ b/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/config/NATSStreamEventQueueProvider.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/config/NATSStreamProperties.java b/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/config/NATSStreamProperties.java index 459ac8723..b864522e7 100644 --- a/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/config/NATSStreamProperties.java +++ b/nats-streaming/src/main/java/com/netflix/conductor/contribs/queue/stan/config/NATSStreamProperties.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/JetStreamObservableQueue.java b/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/JetStreamObservableQueue.java index a5091cbdb..7b54b775b 100644 --- a/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/JetStreamObservableQueue.java +++ b/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/JetStreamObservableQueue.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/JsmMessage.java b/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/JsmMessage.java index 49fb591c5..ddcd7dfa9 100644 --- a/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/JsmMessage.java +++ b/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/JsmMessage.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/NATSAbstractQueue.java b/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/NATSAbstractQueue.java index 1d4b839c4..f838afd2c 100644 --- a/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/NATSAbstractQueue.java +++ b/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/NATSAbstractQueue.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/NATSObservableQueue.java b/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/NATSObservableQueue.java index 51750fc51..8c63640e6 100644 --- a/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/NATSObservableQueue.java +++ b/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/NATSObservableQueue.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/NatsException.java b/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/NatsException.java index 9120d986a..4d21971ad 100644 --- a/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/NatsException.java +++ b/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/NatsException.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/config/JetStreamConfiguration.java b/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/config/JetStreamConfiguration.java index f0d26d285..a0fb07b65 100644 --- a/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/config/JetStreamConfiguration.java +++ b/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/config/JetStreamConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/config/JetStreamEventQueueProvider.java b/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/config/JetStreamEventQueueProvider.java index b6bc20a60..36fb7bf4f 100644 --- a/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/config/JetStreamEventQueueProvider.java +++ b/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/config/JetStreamEventQueueProvider.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/config/JetStreamProperties.java b/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/config/JetStreamProperties.java index 0f4feff1b..7d8305d06 100644 --- a/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/config/JetStreamProperties.java +++ b/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/config/JetStreamProperties.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/config/NATSConfiguration.java b/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/config/NATSConfiguration.java index cc3e7de90..7a707f89b 100644 --- a/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/config/NATSConfiguration.java +++ b/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/config/NATSConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/config/NATSEventQueueProvider.java b/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/config/NATSEventQueueProvider.java index 9b6d346fa..d06f318b6 100644 --- a/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/config/NATSEventQueueProvider.java +++ b/nats/src/main/java/com/netflix/conductor/contribs/queue/nats/config/NATSEventQueueProvider.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/postgres-external-storage/src/main/java/com/netflix/conductor/postgres/config/PostgresPayloadConfiguration.java b/postgres-external-storage/src/main/java/com/netflix/conductor/postgres/config/PostgresPayloadConfiguration.java index fa8c68496..57ea3d908 100644 --- a/postgres-external-storage/src/main/java/com/netflix/conductor/postgres/config/PostgresPayloadConfiguration.java +++ b/postgres-external-storage/src/main/java/com/netflix/conductor/postgres/config/PostgresPayloadConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/postgres-external-storage/src/main/java/com/netflix/conductor/postgres/config/PostgresPayloadProperties.java b/postgres-external-storage/src/main/java/com/netflix/conductor/postgres/config/PostgresPayloadProperties.java index 007a00cce..04b348591 100644 --- a/postgres-external-storage/src/main/java/com/netflix/conductor/postgres/config/PostgresPayloadProperties.java +++ b/postgres-external-storage/src/main/java/com/netflix/conductor/postgres/config/PostgresPayloadProperties.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/postgres-external-storage/src/main/java/com/netflix/conductor/postgres/controller/ExternalPostgresPayloadResource.java b/postgres-external-storage/src/main/java/com/netflix/conductor/postgres/controller/ExternalPostgresPayloadResource.java index 1c485db90..d8e1dae16 100644 --- a/postgres-external-storage/src/main/java/com/netflix/conductor/postgres/controller/ExternalPostgresPayloadResource.java +++ b/postgres-external-storage/src/main/java/com/netflix/conductor/postgres/controller/ExternalPostgresPayloadResource.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/postgres-external-storage/src/main/java/com/netflix/conductor/postgres/storage/PostgresPayloadStorage.java b/postgres-external-storage/src/main/java/com/netflix/conductor/postgres/storage/PostgresPayloadStorage.java index 0df04083a..456199318 100644 --- a/postgres-external-storage/src/main/java/com/netflix/conductor/postgres/storage/PostgresPayloadStorage.java +++ b/postgres-external-storage/src/main/java/com/netflix/conductor/postgres/storage/PostgresPayloadStorage.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/postgres-external-storage/src/test/java/com/netflix/conductor/postgres/controller/ExternalPostgresPayloadResourceTest.java b/postgres-external-storage/src/test/java/com/netflix/conductor/postgres/controller/ExternalPostgresPayloadResourceTest.java index c39e703d5..1c05b5e4d 100644 --- a/postgres-external-storage/src/test/java/com/netflix/conductor/postgres/controller/ExternalPostgresPayloadResourceTest.java +++ b/postgres-external-storage/src/test/java/com/netflix/conductor/postgres/controller/ExternalPostgresPayloadResourceTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/postgres-external-storage/src/test/java/com/netflix/conductor/postgres/storage/PostgresPayloadStorageTest.java b/postgres-external-storage/src/test/java/com/netflix/conductor/postgres/storage/PostgresPayloadStorageTest.java index 31dbf11d5..d16132e2b 100644 --- a/postgres-external-storage/src/test/java/com/netflix/conductor/postgres/storage/PostgresPayloadStorageTest.java +++ b/postgres-external-storage/src/test/java/com/netflix/conductor/postgres/storage/PostgresPayloadStorageTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/postgres-external-storage/src/test/java/com/netflix/conductor/postgres/storage/PostgresPayloadTestUtil.java b/postgres-external-storage/src/test/java/com/netflix/conductor/postgres/storage/PostgresPayloadTestUtil.java index c88cfb8cb..ad7e90892 100644 --- a/postgres-external-storage/src/test/java/com/netflix/conductor/postgres/storage/PostgresPayloadTestUtil.java +++ b/postgres-external-storage/src/test/java/com/netflix/conductor/postgres/storage/PostgresPayloadTestUtil.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/postgres-persistence/src/main/java/com/netflix/conductor/postgres/config/PostgresConfiguration.java b/postgres-persistence/src/main/java/com/netflix/conductor/postgres/config/PostgresConfiguration.java index f41e55a57..62ed27eff 100644 --- a/postgres-persistence/src/main/java/com/netflix/conductor/postgres/config/PostgresConfiguration.java +++ b/postgres-persistence/src/main/java/com/netflix/conductor/postgres/config/PostgresConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/postgres-persistence/src/main/java/com/netflix/conductor/postgres/config/PostgresProperties.java b/postgres-persistence/src/main/java/com/netflix/conductor/postgres/config/PostgresProperties.java index 1166bd4f8..5c392cb52 100644 --- a/postgres-persistence/src/main/java/com/netflix/conductor/postgres/config/PostgresProperties.java +++ b/postgres-persistence/src/main/java/com/netflix/conductor/postgres/config/PostgresProperties.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/postgres-persistence/src/main/java/com/netflix/conductor/postgres/dao/PostgresBaseDAO.java b/postgres-persistence/src/main/java/com/netflix/conductor/postgres/dao/PostgresBaseDAO.java index 57c3ccf77..a0351caab 100644 --- a/postgres-persistence/src/main/java/com/netflix/conductor/postgres/dao/PostgresBaseDAO.java +++ b/postgres-persistence/src/main/java/com/netflix/conductor/postgres/dao/PostgresBaseDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/postgres-persistence/src/main/java/com/netflix/conductor/postgres/dao/PostgresExecutionDAO.java b/postgres-persistence/src/main/java/com/netflix/conductor/postgres/dao/PostgresExecutionDAO.java index a2a358fa2..cf6afae4e 100644 --- a/postgres-persistence/src/main/java/com/netflix/conductor/postgres/dao/PostgresExecutionDAO.java +++ b/postgres-persistence/src/main/java/com/netflix/conductor/postgres/dao/PostgresExecutionDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/postgres-persistence/src/main/java/com/netflix/conductor/postgres/dao/PostgresIndexDAO.java b/postgres-persistence/src/main/java/com/netflix/conductor/postgres/dao/PostgresIndexDAO.java index d50407536..cbd36da28 100644 --- a/postgres-persistence/src/main/java/com/netflix/conductor/postgres/dao/PostgresIndexDAO.java +++ b/postgres-persistence/src/main/java/com/netflix/conductor/postgres/dao/PostgresIndexDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/postgres-persistence/src/main/java/com/netflix/conductor/postgres/dao/PostgresMetadataDAO.java b/postgres-persistence/src/main/java/com/netflix/conductor/postgres/dao/PostgresMetadataDAO.java index ab8c5acd1..81decfe83 100644 --- a/postgres-persistence/src/main/java/com/netflix/conductor/postgres/dao/PostgresMetadataDAO.java +++ b/postgres-persistence/src/main/java/com/netflix/conductor/postgres/dao/PostgresMetadataDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/postgres-persistence/src/main/java/com/netflix/conductor/postgres/dao/PostgresQueueDAO.java b/postgres-persistence/src/main/java/com/netflix/conductor/postgres/dao/PostgresQueueDAO.java index 206bd8569..693b48c06 100644 --- a/postgres-persistence/src/main/java/com/netflix/conductor/postgres/dao/PostgresQueueDAO.java +++ b/postgres-persistence/src/main/java/com/netflix/conductor/postgres/dao/PostgresQueueDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/ExecuteFunction.java b/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/ExecuteFunction.java index 829bbded2..1deaa0c23 100644 --- a/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/ExecuteFunction.java +++ b/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/ExecuteFunction.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/ExecutorsUtil.java b/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/ExecutorsUtil.java index f0c3b3999..84824cbb4 100644 --- a/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/ExecutorsUtil.java +++ b/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/ExecutorsUtil.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/LazyToString.java b/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/LazyToString.java index 2b2370950..03d35c31e 100644 --- a/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/LazyToString.java +++ b/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/LazyToString.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/PostgresIndexQueryBuilder.java b/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/PostgresIndexQueryBuilder.java index 74ce8c7ee..141df11b2 100644 --- a/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/PostgresIndexQueryBuilder.java +++ b/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/PostgresIndexQueryBuilder.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/Query.java b/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/Query.java index d65115c46..ae96161b6 100644 --- a/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/Query.java +++ b/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/Query.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/QueryFunction.java b/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/QueryFunction.java index d0f16e31a..d32107bcf 100644 --- a/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/QueryFunction.java +++ b/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/QueryFunction.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/ResultSetHandler.java b/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/ResultSetHandler.java index 838146ffe..2e45806c5 100644 --- a/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/ResultSetHandler.java +++ b/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/ResultSetHandler.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/TransactionalFunction.java b/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/TransactionalFunction.java index c790947ed..45b94a051 100644 --- a/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/TransactionalFunction.java +++ b/postgres-persistence/src/main/java/com/netflix/conductor/postgres/util/TransactionalFunction.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/postgres-persistence/src/test/java/com/netflix/conductor/postgres/dao/PostgresExecutionDAOTest.java b/postgres-persistence/src/test/java/com/netflix/conductor/postgres/dao/PostgresExecutionDAOTest.java index b1563b38e..8ab410b3d 100644 --- a/postgres-persistence/src/test/java/com/netflix/conductor/postgres/dao/PostgresExecutionDAOTest.java +++ b/postgres-persistence/src/test/java/com/netflix/conductor/postgres/dao/PostgresExecutionDAOTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/postgres-persistence/src/test/java/com/netflix/conductor/postgres/dao/PostgresIndexDAOTest.java b/postgres-persistence/src/test/java/com/netflix/conductor/postgres/dao/PostgresIndexDAOTest.java index 73f62b68d..c6238b6a8 100644 --- a/postgres-persistence/src/test/java/com/netflix/conductor/postgres/dao/PostgresIndexDAOTest.java +++ b/postgres-persistence/src/test/java/com/netflix/conductor/postgres/dao/PostgresIndexDAOTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/postgres-persistence/src/test/java/com/netflix/conductor/postgres/dao/PostgresMetadataDAOTest.java b/postgres-persistence/src/test/java/com/netflix/conductor/postgres/dao/PostgresMetadataDAOTest.java index f86ae78bd..252b096f6 100644 --- a/postgres-persistence/src/test/java/com/netflix/conductor/postgres/dao/PostgresMetadataDAOTest.java +++ b/postgres-persistence/src/test/java/com/netflix/conductor/postgres/dao/PostgresMetadataDAOTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/postgres-persistence/src/test/java/com/netflix/conductor/postgres/dao/PostgresQueueDAOTest.java b/postgres-persistence/src/test/java/com/netflix/conductor/postgres/dao/PostgresQueueDAOTest.java index da22860e8..9cff8e672 100644 --- a/postgres-persistence/src/test/java/com/netflix/conductor/postgres/dao/PostgresQueueDAOTest.java +++ b/postgres-persistence/src/test/java/com/netflix/conductor/postgres/dao/PostgresQueueDAOTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/postgres-persistence/src/test/java/com/netflix/conductor/postgres/performance/PerformanceTest.java b/postgres-persistence/src/test/java/com/netflix/conductor/postgres/performance/PerformanceTest.java index 1825fbb01..aac58ef7a 100644 --- a/postgres-persistence/src/test/java/com/netflix/conductor/postgres/performance/PerformanceTest.java +++ b/postgres-persistence/src/test/java/com/netflix/conductor/postgres/performance/PerformanceTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/postgres-persistence/src/test/java/com/netflix/conductor/postgres/util/PostgresIndexQueryBuilderTest.java b/postgres-persistence/src/test/java/com/netflix/conductor/postgres/util/PostgresIndexQueryBuilderTest.java index fdce7a3f2..2036e2f4a 100644 --- a/postgres-persistence/src/test/java/com/netflix/conductor/postgres/util/PostgresIndexQueryBuilderTest.java +++ b/postgres-persistence/src/test/java/com/netflix/conductor/postgres/util/PostgresIndexQueryBuilderTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/postgres-persistence/src/test/java/com/netflix/conductor/test/integration/grpc/postgres/PostgresGrpcEndToEndTest.java b/postgres-persistence/src/test/java/com/netflix/conductor/test/integration/grpc/postgres/PostgresGrpcEndToEndTest.java index 98320e851..657b402a4 100644 --- a/postgres-persistence/src/test/java/com/netflix/conductor/test/integration/grpc/postgres/PostgresGrpcEndToEndTest.java +++ b/postgres-persistence/src/test/java/com/netflix/conductor/test/integration/grpc/postgres/PostgresGrpcEndToEndTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-concurrency-limit/src/main/java/com/netflix/conductor/redis/limit/RedisConcurrentExecutionLimitDAO.java b/redis-concurrency-limit/src/main/java/com/netflix/conductor/redis/limit/RedisConcurrentExecutionLimitDAO.java index ceb7fec10..7107227ab 100644 --- a/redis-concurrency-limit/src/main/java/com/netflix/conductor/redis/limit/RedisConcurrentExecutionLimitDAO.java +++ b/redis-concurrency-limit/src/main/java/com/netflix/conductor/redis/limit/RedisConcurrentExecutionLimitDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-concurrency-limit/src/main/java/com/netflix/conductor/redis/limit/config/RedisConcurrentExecutionLimitConfiguration.java b/redis-concurrency-limit/src/main/java/com/netflix/conductor/redis/limit/config/RedisConcurrentExecutionLimitConfiguration.java index 9349093eb..5abf76300 100644 --- a/redis-concurrency-limit/src/main/java/com/netflix/conductor/redis/limit/config/RedisConcurrentExecutionLimitConfiguration.java +++ b/redis-concurrency-limit/src/main/java/com/netflix/conductor/redis/limit/config/RedisConcurrentExecutionLimitConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-concurrency-limit/src/main/java/com/netflix/conductor/redis/limit/config/RedisConcurrentExecutionLimitProperties.java b/redis-concurrency-limit/src/main/java/com/netflix/conductor/redis/limit/config/RedisConcurrentExecutionLimitProperties.java index 20b0e929d..be7ab3466 100644 --- a/redis-concurrency-limit/src/main/java/com/netflix/conductor/redis/limit/config/RedisConcurrentExecutionLimitProperties.java +++ b/redis-concurrency-limit/src/main/java/com/netflix/conductor/redis/limit/config/RedisConcurrentExecutionLimitProperties.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-concurrency-limit/src/test/groovy/com/netflix/conductor/redis/limit/RedisConcurrentExecutionLimitDAOSpec.groovy b/redis-concurrency-limit/src/test/groovy/com/netflix/conductor/redis/limit/RedisConcurrentExecutionLimitDAOSpec.groovy index 9cb4d4239..e768a4a3d 100644 --- a/redis-concurrency-limit/src/test/groovy/com/netflix/conductor/redis/limit/RedisConcurrentExecutionLimitDAOSpec.groovy +++ b/redis-concurrency-limit/src/test/groovy/com/netflix/conductor/redis/limit/RedisConcurrentExecutionLimitDAOSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-lock/src/main/java/com/netflix/conductor/redislock/config/RedisLockConfiguration.java b/redis-lock/src/main/java/com/netflix/conductor/redislock/config/RedisLockConfiguration.java index 7d03890e6..9df1135e2 100644 --- a/redis-lock/src/main/java/com/netflix/conductor/redislock/config/RedisLockConfiguration.java +++ b/redis-lock/src/main/java/com/netflix/conductor/redislock/config/RedisLockConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-lock/src/main/java/com/netflix/conductor/redislock/config/RedisLockProperties.java b/redis-lock/src/main/java/com/netflix/conductor/redislock/config/RedisLockProperties.java index c7ea9e983..f5560012f 100644 --- a/redis-lock/src/main/java/com/netflix/conductor/redislock/config/RedisLockProperties.java +++ b/redis-lock/src/main/java/com/netflix/conductor/redislock/config/RedisLockProperties.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-lock/src/main/java/com/netflix/conductor/redislock/lock/RedisLock.java b/redis-lock/src/main/java/com/netflix/conductor/redislock/lock/RedisLock.java index 28cdcfef8..433bacf6f 100644 --- a/redis-lock/src/main/java/com/netflix/conductor/redislock/lock/RedisLock.java +++ b/redis-lock/src/main/java/com/netflix/conductor/redislock/lock/RedisLock.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-lock/src/test/java/com/netflix/conductor/redis/lock/RedisLockTest.java b/redis-lock/src/test/java/com/netflix/conductor/redis/lock/RedisLockTest.java index 24953dd7b..184e5ff37 100644 --- a/redis-lock/src/test/java/com/netflix/conductor/redis/lock/RedisLockTest.java +++ b/redis-lock/src/test/java/com/netflix/conductor/redis/lock/RedisLockTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/main/java/com/netflix/conductor/redis/config/AnyRedisCondition.java b/redis-persistence/src/main/java/com/netflix/conductor/redis/config/AnyRedisCondition.java index 0303c9f80..cfeecb7f8 100644 --- a/redis-persistence/src/main/java/com/netflix/conductor/redis/config/AnyRedisCondition.java +++ b/redis-persistence/src/main/java/com/netflix/conductor/redis/config/AnyRedisCondition.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/main/java/com/netflix/conductor/redis/config/DynomiteClusterConfiguration.java b/redis-persistence/src/main/java/com/netflix/conductor/redis/config/DynomiteClusterConfiguration.java index 410f96f16..5fbe20bdb 100644 --- a/redis-persistence/src/main/java/com/netflix/conductor/redis/config/DynomiteClusterConfiguration.java +++ b/redis-persistence/src/main/java/com/netflix/conductor/redis/config/DynomiteClusterConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/main/java/com/netflix/conductor/redis/config/InMemoryRedisConfiguration.java b/redis-persistence/src/main/java/com/netflix/conductor/redis/config/InMemoryRedisConfiguration.java index 1d03de008..e7d2b2fa2 100644 --- a/redis-persistence/src/main/java/com/netflix/conductor/redis/config/InMemoryRedisConfiguration.java +++ b/redis-persistence/src/main/java/com/netflix/conductor/redis/config/InMemoryRedisConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/main/java/com/netflix/conductor/redis/config/JedisCommandsConfigurer.java b/redis-persistence/src/main/java/com/netflix/conductor/redis/config/JedisCommandsConfigurer.java index 5f4783406..03618aad8 100644 --- a/redis-persistence/src/main/java/com/netflix/conductor/redis/config/JedisCommandsConfigurer.java +++ b/redis-persistence/src/main/java/com/netflix/conductor/redis/config/JedisCommandsConfigurer.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/main/java/com/netflix/conductor/redis/config/RedisClusterConfiguration.java b/redis-persistence/src/main/java/com/netflix/conductor/redis/config/RedisClusterConfiguration.java index b98e038f7..9aa823e1c 100644 --- a/redis-persistence/src/main/java/com/netflix/conductor/redis/config/RedisClusterConfiguration.java +++ b/redis-persistence/src/main/java/com/netflix/conductor/redis/config/RedisClusterConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/main/java/com/netflix/conductor/redis/config/RedisCommonConfiguration.java b/redis-persistence/src/main/java/com/netflix/conductor/redis/config/RedisCommonConfiguration.java index 94883f6f5..6b40e34fd 100644 --- a/redis-persistence/src/main/java/com/netflix/conductor/redis/config/RedisCommonConfiguration.java +++ b/redis-persistence/src/main/java/com/netflix/conductor/redis/config/RedisCommonConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/main/java/com/netflix/conductor/redis/config/RedisProperties.java b/redis-persistence/src/main/java/com/netflix/conductor/redis/config/RedisProperties.java index 905fd65aa..7813e5519 100644 --- a/redis-persistence/src/main/java/com/netflix/conductor/redis/config/RedisProperties.java +++ b/redis-persistence/src/main/java/com/netflix/conductor/redis/config/RedisProperties.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/main/java/com/netflix/conductor/redis/config/RedisSentinelConfiguration.java b/redis-persistence/src/main/java/com/netflix/conductor/redis/config/RedisSentinelConfiguration.java index aa35f5e67..54abd17ca 100644 --- a/redis-persistence/src/main/java/com/netflix/conductor/redis/config/RedisSentinelConfiguration.java +++ b/redis-persistence/src/main/java/com/netflix/conductor/redis/config/RedisSentinelConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/main/java/com/netflix/conductor/redis/config/RedisStandaloneConfiguration.java b/redis-persistence/src/main/java/com/netflix/conductor/redis/config/RedisStandaloneConfiguration.java index 5d07cc34f..2156b50fe 100644 --- a/redis-persistence/src/main/java/com/netflix/conductor/redis/config/RedisStandaloneConfiguration.java +++ b/redis-persistence/src/main/java/com/netflix/conductor/redis/config/RedisStandaloneConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/main/java/com/netflix/conductor/redis/dao/BaseDynoDAO.java b/redis-persistence/src/main/java/com/netflix/conductor/redis/dao/BaseDynoDAO.java index bdf881fbb..95a363f87 100644 --- a/redis-persistence/src/main/java/com/netflix/conductor/redis/dao/BaseDynoDAO.java +++ b/redis-persistence/src/main/java/com/netflix/conductor/redis/dao/BaseDynoDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/main/java/com/netflix/conductor/redis/dao/DynoQueueDAO.java b/redis-persistence/src/main/java/com/netflix/conductor/redis/dao/DynoQueueDAO.java index 3901931dc..76bd72bde 100644 --- a/redis-persistence/src/main/java/com/netflix/conductor/redis/dao/DynoQueueDAO.java +++ b/redis-persistence/src/main/java/com/netflix/conductor/redis/dao/DynoQueueDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/main/java/com/netflix/conductor/redis/dao/RedisEventHandlerDAO.java b/redis-persistence/src/main/java/com/netflix/conductor/redis/dao/RedisEventHandlerDAO.java index e0aa0bfd8..2942c18d2 100644 --- a/redis-persistence/src/main/java/com/netflix/conductor/redis/dao/RedisEventHandlerDAO.java +++ b/redis-persistence/src/main/java/com/netflix/conductor/redis/dao/RedisEventHandlerDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/main/java/com/netflix/conductor/redis/dao/RedisExecutionDAO.java b/redis-persistence/src/main/java/com/netflix/conductor/redis/dao/RedisExecutionDAO.java index 33902640d..b5fbff6a0 100644 --- a/redis-persistence/src/main/java/com/netflix/conductor/redis/dao/RedisExecutionDAO.java +++ b/redis-persistence/src/main/java/com/netflix/conductor/redis/dao/RedisExecutionDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/main/java/com/netflix/conductor/redis/dao/RedisMetadataDAO.java b/redis-persistence/src/main/java/com/netflix/conductor/redis/dao/RedisMetadataDAO.java index f7951c1e3..03bc41c0c 100644 --- a/redis-persistence/src/main/java/com/netflix/conductor/redis/dao/RedisMetadataDAO.java +++ b/redis-persistence/src/main/java/com/netflix/conductor/redis/dao/RedisMetadataDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/main/java/com/netflix/conductor/redis/dao/RedisPollDataDAO.java b/redis-persistence/src/main/java/com/netflix/conductor/redis/dao/RedisPollDataDAO.java index 717e582a7..053d6a08c 100644 --- a/redis-persistence/src/main/java/com/netflix/conductor/redis/dao/RedisPollDataDAO.java +++ b/redis-persistence/src/main/java/com/netflix/conductor/redis/dao/RedisPollDataDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/main/java/com/netflix/conductor/redis/dao/RedisRateLimitingDAO.java b/redis-persistence/src/main/java/com/netflix/conductor/redis/dao/RedisRateLimitingDAO.java index 9535dc4cc..af42082b8 100644 --- a/redis-persistence/src/main/java/com/netflix/conductor/redis/dao/RedisRateLimitingDAO.java +++ b/redis-persistence/src/main/java/com/netflix/conductor/redis/dao/RedisRateLimitingDAO.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/main/java/com/netflix/conductor/redis/dynoqueue/ConfigurationHostSupplier.java b/redis-persistence/src/main/java/com/netflix/conductor/redis/dynoqueue/ConfigurationHostSupplier.java index 9e32a1d5f..562a91ee1 100644 --- a/redis-persistence/src/main/java/com/netflix/conductor/redis/dynoqueue/ConfigurationHostSupplier.java +++ b/redis-persistence/src/main/java/com/netflix/conductor/redis/dynoqueue/ConfigurationHostSupplier.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/main/java/com/netflix/conductor/redis/dynoqueue/LocalhostHostSupplier.java b/redis-persistence/src/main/java/com/netflix/conductor/redis/dynoqueue/LocalhostHostSupplier.java index 7f1823af8..108c1c95c 100644 --- a/redis-persistence/src/main/java/com/netflix/conductor/redis/dynoqueue/LocalhostHostSupplier.java +++ b/redis-persistence/src/main/java/com/netflix/conductor/redis/dynoqueue/LocalhostHostSupplier.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/main/java/com/netflix/conductor/redis/dynoqueue/RedisQueuesShardingStrategyProvider.java b/redis-persistence/src/main/java/com/netflix/conductor/redis/dynoqueue/RedisQueuesShardingStrategyProvider.java index 2ba4528bb..5a76cb901 100644 --- a/redis-persistence/src/main/java/com/netflix/conductor/redis/dynoqueue/RedisQueuesShardingStrategyProvider.java +++ b/redis-persistence/src/main/java/com/netflix/conductor/redis/dynoqueue/RedisQueuesShardingStrategyProvider.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/main/java/com/netflix/conductor/redis/jedis/JedisCluster.java b/redis-persistence/src/main/java/com/netflix/conductor/redis/jedis/JedisCluster.java index b757f88c7..bf5ea5c97 100644 --- a/redis-persistence/src/main/java/com/netflix/conductor/redis/jedis/JedisCluster.java +++ b/redis-persistence/src/main/java/com/netflix/conductor/redis/jedis/JedisCluster.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/main/java/com/netflix/conductor/redis/jedis/JedisMock.java b/redis-persistence/src/main/java/com/netflix/conductor/redis/jedis/JedisMock.java index 169146be3..b6de5b5c1 100644 --- a/redis-persistence/src/main/java/com/netflix/conductor/redis/jedis/JedisMock.java +++ b/redis-persistence/src/main/java/com/netflix/conductor/redis/jedis/JedisMock.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/main/java/com/netflix/conductor/redis/jedis/JedisProxy.java b/redis-persistence/src/main/java/com/netflix/conductor/redis/jedis/JedisProxy.java index 38abcb964..902809b3c 100644 --- a/redis-persistence/src/main/java/com/netflix/conductor/redis/jedis/JedisProxy.java +++ b/redis-persistence/src/main/java/com/netflix/conductor/redis/jedis/JedisProxy.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/main/java/com/netflix/conductor/redis/jedis/JedisSentinel.java b/redis-persistence/src/main/java/com/netflix/conductor/redis/jedis/JedisSentinel.java index 50f603228..27aee1f06 100644 --- a/redis-persistence/src/main/java/com/netflix/conductor/redis/jedis/JedisSentinel.java +++ b/redis-persistence/src/main/java/com/netflix/conductor/redis/jedis/JedisSentinel.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/main/java/com/netflix/conductor/redis/jedis/JedisStandalone.java b/redis-persistence/src/main/java/com/netflix/conductor/redis/jedis/JedisStandalone.java index 97b326e44..2a5cb2c49 100644 --- a/redis-persistence/src/main/java/com/netflix/conductor/redis/jedis/JedisStandalone.java +++ b/redis-persistence/src/main/java/com/netflix/conductor/redis/jedis/JedisStandalone.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/test/java/com/netflix/conductor/redis/config/utils/RedisQueuesShardingStrategyProviderTest.java b/redis-persistence/src/test/java/com/netflix/conductor/redis/config/utils/RedisQueuesShardingStrategyProviderTest.java index 2ec4b3470..3f10f3bf6 100644 --- a/redis-persistence/src/test/java/com/netflix/conductor/redis/config/utils/RedisQueuesShardingStrategyProviderTest.java +++ b/redis-persistence/src/test/java/com/netflix/conductor/redis/config/utils/RedisQueuesShardingStrategyProviderTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/test/java/com/netflix/conductor/redis/dao/BaseDynoDAOTest.java b/redis-persistence/src/test/java/com/netflix/conductor/redis/dao/BaseDynoDAOTest.java index a3ce44e52..72c643ca2 100644 --- a/redis-persistence/src/test/java/com/netflix/conductor/redis/dao/BaseDynoDAOTest.java +++ b/redis-persistence/src/test/java/com/netflix/conductor/redis/dao/BaseDynoDAOTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/test/java/com/netflix/conductor/redis/dao/DynoQueueDAOTest.java b/redis-persistence/src/test/java/com/netflix/conductor/redis/dao/DynoQueueDAOTest.java index 6efa7ccd4..b2cf461b7 100644 --- a/redis-persistence/src/test/java/com/netflix/conductor/redis/dao/DynoQueueDAOTest.java +++ b/redis-persistence/src/test/java/com/netflix/conductor/redis/dao/DynoQueueDAOTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/test/java/com/netflix/conductor/redis/dao/RedisEventHandlerDAOTest.java b/redis-persistence/src/test/java/com/netflix/conductor/redis/dao/RedisEventHandlerDAOTest.java index 6b53f00e6..daca09135 100644 --- a/redis-persistence/src/test/java/com/netflix/conductor/redis/dao/RedisEventHandlerDAOTest.java +++ b/redis-persistence/src/test/java/com/netflix/conductor/redis/dao/RedisEventHandlerDAOTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/test/java/com/netflix/conductor/redis/dao/RedisExecutionDAOTest.java b/redis-persistence/src/test/java/com/netflix/conductor/redis/dao/RedisExecutionDAOTest.java index 7bc844f39..6fe5e61a2 100644 --- a/redis-persistence/src/test/java/com/netflix/conductor/redis/dao/RedisExecutionDAOTest.java +++ b/redis-persistence/src/test/java/com/netflix/conductor/redis/dao/RedisExecutionDAOTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/test/java/com/netflix/conductor/redis/dao/RedisMetadataDAOTest.java b/redis-persistence/src/test/java/com/netflix/conductor/redis/dao/RedisMetadataDAOTest.java index fd9119162..ece7c6e37 100644 --- a/redis-persistence/src/test/java/com/netflix/conductor/redis/dao/RedisMetadataDAOTest.java +++ b/redis-persistence/src/test/java/com/netflix/conductor/redis/dao/RedisMetadataDAOTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/test/java/com/netflix/conductor/redis/dao/RedisPollDataDAOTest.java b/redis-persistence/src/test/java/com/netflix/conductor/redis/dao/RedisPollDataDAOTest.java index 3553856ce..4768946f7 100644 --- a/redis-persistence/src/test/java/com/netflix/conductor/redis/dao/RedisPollDataDAOTest.java +++ b/redis-persistence/src/test/java/com/netflix/conductor/redis/dao/RedisPollDataDAOTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/test/java/com/netflix/conductor/redis/dao/RedisRateLimitDAOTest.java b/redis-persistence/src/test/java/com/netflix/conductor/redis/dao/RedisRateLimitDAOTest.java index 30877fc18..78f8c8bcc 100644 --- a/redis-persistence/src/test/java/com/netflix/conductor/redis/dao/RedisRateLimitDAOTest.java +++ b/redis-persistence/src/test/java/com/netflix/conductor/redis/dao/RedisRateLimitDAOTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/test/java/com/netflix/conductor/redis/jedis/ConfigurationHostSupplierTest.java b/redis-persistence/src/test/java/com/netflix/conductor/redis/jedis/ConfigurationHostSupplierTest.java index 7760c68a3..1be01322d 100644 --- a/redis-persistence/src/test/java/com/netflix/conductor/redis/jedis/ConfigurationHostSupplierTest.java +++ b/redis-persistence/src/test/java/com/netflix/conductor/redis/jedis/ConfigurationHostSupplierTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/test/java/com/netflix/conductor/redis/jedis/JedisClusterTest.java b/redis-persistence/src/test/java/com/netflix/conductor/redis/jedis/JedisClusterTest.java index e69b22a46..965313593 100644 --- a/redis-persistence/src/test/java/com/netflix/conductor/redis/jedis/JedisClusterTest.java +++ b/redis-persistence/src/test/java/com/netflix/conductor/redis/jedis/JedisClusterTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/redis-persistence/src/test/java/com/netflix/conductor/redis/jedis/JedisSentinelTest.java b/redis-persistence/src/test/java/com/netflix/conductor/redis/jedis/JedisSentinelTest.java index b38e13468..7137c5688 100644 --- a/redis-persistence/src/test/java/com/netflix/conductor/redis/jedis/JedisSentinelTest.java +++ b/redis-persistence/src/test/java/com/netflix/conductor/redis/jedis/JedisSentinelTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/rest/src/main/java/com/netflix/conductor/rest/config/RequestMappingConstants.java b/rest/src/main/java/com/netflix/conductor/rest/config/RequestMappingConstants.java index 940d3fb92..3bae355e3 100644 --- a/rest/src/main/java/com/netflix/conductor/rest/config/RequestMappingConstants.java +++ b/rest/src/main/java/com/netflix/conductor/rest/config/RequestMappingConstants.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/rest/src/main/java/com/netflix/conductor/rest/config/RestConfiguration.java b/rest/src/main/java/com/netflix/conductor/rest/config/RestConfiguration.java index e4b001591..144ef9349 100644 --- a/rest/src/main/java/com/netflix/conductor/rest/config/RestConfiguration.java +++ b/rest/src/main/java/com/netflix/conductor/rest/config/RestConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/rest/src/main/java/com/netflix/conductor/rest/controllers/AdminResource.java b/rest/src/main/java/com/netflix/conductor/rest/controllers/AdminResource.java index 4221917c5..bb1c6a6bb 100644 --- a/rest/src/main/java/com/netflix/conductor/rest/controllers/AdminResource.java +++ b/rest/src/main/java/com/netflix/conductor/rest/controllers/AdminResource.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/rest/src/main/java/com/netflix/conductor/rest/controllers/ApplicationExceptionMapper.java b/rest/src/main/java/com/netflix/conductor/rest/controllers/ApplicationExceptionMapper.java index f61b8e95d..6aa1aa904 100644 --- a/rest/src/main/java/com/netflix/conductor/rest/controllers/ApplicationExceptionMapper.java +++ b/rest/src/main/java/com/netflix/conductor/rest/controllers/ApplicationExceptionMapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/rest/src/main/java/com/netflix/conductor/rest/controllers/EventResource.java b/rest/src/main/java/com/netflix/conductor/rest/controllers/EventResource.java index 02b620c1e..0339ce2f2 100644 --- a/rest/src/main/java/com/netflix/conductor/rest/controllers/EventResource.java +++ b/rest/src/main/java/com/netflix/conductor/rest/controllers/EventResource.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/rest/src/main/java/com/netflix/conductor/rest/controllers/HealthCheckResource.java b/rest/src/main/java/com/netflix/conductor/rest/controllers/HealthCheckResource.java index ffd3767ad..43b0658a2 100644 --- a/rest/src/main/java/com/netflix/conductor/rest/controllers/HealthCheckResource.java +++ b/rest/src/main/java/com/netflix/conductor/rest/controllers/HealthCheckResource.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/rest/src/main/java/com/netflix/conductor/rest/controllers/MetadataResource.java b/rest/src/main/java/com/netflix/conductor/rest/controllers/MetadataResource.java index 023ed2b57..5ffda1ed4 100644 --- a/rest/src/main/java/com/netflix/conductor/rest/controllers/MetadataResource.java +++ b/rest/src/main/java/com/netflix/conductor/rest/controllers/MetadataResource.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/rest/src/main/java/com/netflix/conductor/rest/controllers/QueueAdminResource.java b/rest/src/main/java/com/netflix/conductor/rest/controllers/QueueAdminResource.java index 70eb05872..6651352e9 100644 --- a/rest/src/main/java/com/netflix/conductor/rest/controllers/QueueAdminResource.java +++ b/rest/src/main/java/com/netflix/conductor/rest/controllers/QueueAdminResource.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/rest/src/main/java/com/netflix/conductor/rest/controllers/TaskResource.java b/rest/src/main/java/com/netflix/conductor/rest/controllers/TaskResource.java index d9f818f44..b606c622d 100644 --- a/rest/src/main/java/com/netflix/conductor/rest/controllers/TaskResource.java +++ b/rest/src/main/java/com/netflix/conductor/rest/controllers/TaskResource.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/rest/src/main/java/com/netflix/conductor/rest/controllers/ValidationExceptionMapper.java b/rest/src/main/java/com/netflix/conductor/rest/controllers/ValidationExceptionMapper.java index 928e7419f..68cc36d5d 100644 --- a/rest/src/main/java/com/netflix/conductor/rest/controllers/ValidationExceptionMapper.java +++ b/rest/src/main/java/com/netflix/conductor/rest/controllers/ValidationExceptionMapper.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/rest/src/main/java/com/netflix/conductor/rest/controllers/WorkflowBulkResource.java b/rest/src/main/java/com/netflix/conductor/rest/controllers/WorkflowBulkResource.java index 409328e81..6c5d99ff1 100644 --- a/rest/src/main/java/com/netflix/conductor/rest/controllers/WorkflowBulkResource.java +++ b/rest/src/main/java/com/netflix/conductor/rest/controllers/WorkflowBulkResource.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/rest/src/main/java/com/netflix/conductor/rest/controllers/WorkflowResource.java b/rest/src/main/java/com/netflix/conductor/rest/controllers/WorkflowResource.java index 263404b2d..7200ab756 100644 --- a/rest/src/main/java/com/netflix/conductor/rest/controllers/WorkflowResource.java +++ b/rest/src/main/java/com/netflix/conductor/rest/controllers/WorkflowResource.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/rest/src/main/java/com/netflix/conductor/rest/startup/KitchenSinkInitializer.java b/rest/src/main/java/com/netflix/conductor/rest/startup/KitchenSinkInitializer.java index e69d9cada..017294aba 100644 --- a/rest/src/main/java/com/netflix/conductor/rest/startup/KitchenSinkInitializer.java +++ b/rest/src/main/java/com/netflix/conductor/rest/startup/KitchenSinkInitializer.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/rest/src/test/java/com/netflix/conductor/rest/controllers/AdminResourceTest.java b/rest/src/test/java/com/netflix/conductor/rest/controllers/AdminResourceTest.java index 83639be47..73e7defd4 100644 --- a/rest/src/test/java/com/netflix/conductor/rest/controllers/AdminResourceTest.java +++ b/rest/src/test/java/com/netflix/conductor/rest/controllers/AdminResourceTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/rest/src/test/java/com/netflix/conductor/rest/controllers/EventResourceTest.java b/rest/src/test/java/com/netflix/conductor/rest/controllers/EventResourceTest.java index ae1adffb6..2f6f2c49b 100644 --- a/rest/src/test/java/com/netflix/conductor/rest/controllers/EventResourceTest.java +++ b/rest/src/test/java/com/netflix/conductor/rest/controllers/EventResourceTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/rest/src/test/java/com/netflix/conductor/rest/controllers/MetadataResourceTest.java b/rest/src/test/java/com/netflix/conductor/rest/controllers/MetadataResourceTest.java index 36d5b6e70..fc50b15be 100644 --- a/rest/src/test/java/com/netflix/conductor/rest/controllers/MetadataResourceTest.java +++ b/rest/src/test/java/com/netflix/conductor/rest/controllers/MetadataResourceTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/rest/src/test/java/com/netflix/conductor/rest/controllers/TaskResourceTest.java b/rest/src/test/java/com/netflix/conductor/rest/controllers/TaskResourceTest.java index b9dd18d23..5e0e04e13 100644 --- a/rest/src/test/java/com/netflix/conductor/rest/controllers/TaskResourceTest.java +++ b/rest/src/test/java/com/netflix/conductor/rest/controllers/TaskResourceTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/rest/src/test/java/com/netflix/conductor/rest/controllers/WorkflowResourceTest.java b/rest/src/test/java/com/netflix/conductor/rest/controllers/WorkflowResourceTest.java index 60759bc62..8c10bc346 100644 --- a/rest/src/test/java/com/netflix/conductor/rest/controllers/WorkflowResourceTest.java +++ b/rest/src/test/java/com/netflix/conductor/rest/controllers/WorkflowResourceTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/server/src/main/java/com/netflix/conductor/Conductor.java b/server/src/main/java/com/netflix/conductor/Conductor.java index aa55b7804..10a0f85bd 100644 --- a/server/src/main/java/com/netflix/conductor/Conductor.java +++ b/server/src/main/java/com/netflix/conductor/Conductor.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/server/src/test/java/com/netflix/conductor/common/config/ConductorObjectMapperTest.java b/server/src/test/java/com/netflix/conductor/common/config/ConductorObjectMapperTest.java index a02b7ce34..078514d24 100644 --- a/server/src/test/java/com/netflix/conductor/common/config/ConductorObjectMapperTest.java +++ b/server/src/test/java/com/netflix/conductor/common/config/ConductorObjectMapperTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/base/AbstractResiliencySpecification.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/base/AbstractResiliencySpecification.groovy index d3270c447..0ad2a7f87 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/base/AbstractResiliencySpecification.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/base/AbstractResiliencySpecification.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/base/AbstractSpecification.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/base/AbstractSpecification.groovy index 6d43a7424..974f30001 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/base/AbstractSpecification.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/base/AbstractSpecification.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/DecisionTaskSpec.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/DecisionTaskSpec.groovy index 2d46ae360..158059bf6 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/DecisionTaskSpec.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/DecisionTaskSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/DoWhileSpec.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/DoWhileSpec.groovy index 33ba261c8..5b3327088 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/DoWhileSpec.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/DoWhileSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/DynamicForkJoinSpec.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/DynamicForkJoinSpec.groovy index d7dac2993..723748fe4 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/DynamicForkJoinSpec.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/DynamicForkJoinSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/EventTaskSpec.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/EventTaskSpec.groovy index 189eeaaf0..60d6d528a 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/EventTaskSpec.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/EventTaskSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/ExclusiveJoinSpec.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/ExclusiveJoinSpec.groovy index e4681dcc9..faa805186 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/ExclusiveJoinSpec.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/ExclusiveJoinSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/ExternalPayloadStorageSpec.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/ExternalPayloadStorageSpec.groovy index ea1393975..2edbc6099 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/ExternalPayloadStorageSpec.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/ExternalPayloadStorageSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/FailureWorkflowSpec.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/FailureWorkflowSpec.groovy index c5168ef70..26f1955e5 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/FailureWorkflowSpec.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/FailureWorkflowSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/ForkJoinSpec.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/ForkJoinSpec.groovy index 437f4e1cc..83407e7e8 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/ForkJoinSpec.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/ForkJoinSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/HierarchicalForkJoinSubworkflowRerunSpec.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/HierarchicalForkJoinSubworkflowRerunSpec.groovy index 5e6d8c0be..03d077ea0 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/HierarchicalForkJoinSubworkflowRerunSpec.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/HierarchicalForkJoinSubworkflowRerunSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/HierarchicalForkJoinSubworkflowRestartSpec.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/HierarchicalForkJoinSubworkflowRestartSpec.groovy index 61fdd055e..279a48fb2 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/HierarchicalForkJoinSubworkflowRestartSpec.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/HierarchicalForkJoinSubworkflowRestartSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/HierarchicalForkJoinSubworkflowRetrySpec.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/HierarchicalForkJoinSubworkflowRetrySpec.groovy index 5bd155249..56d78bfc2 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/HierarchicalForkJoinSubworkflowRetrySpec.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/HierarchicalForkJoinSubworkflowRetrySpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/JsonJQTransformSpec.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/JsonJQTransformSpec.groovy index 006c367f0..c05b5c48e 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/JsonJQTransformSpec.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/JsonJQTransformSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/LambdaAndTerminateTaskSpec.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/LambdaAndTerminateTaskSpec.groovy index 281b2d71d..fd6c6cb14 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/LambdaAndTerminateTaskSpec.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/LambdaAndTerminateTaskSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/NestedForkJoinSubWorkflowSpec.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/NestedForkJoinSubWorkflowSpec.groovy index 61eca08ab..548418531 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/NestedForkJoinSubWorkflowSpec.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/NestedForkJoinSubWorkflowSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SetVariableTaskSpec.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SetVariableTaskSpec.groovy index 714300f48..633cca258 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SetVariableTaskSpec.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SetVariableTaskSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SimpleWorkflowSpec.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SimpleWorkflowSpec.groovy index 539a3d9d6..1134078ac 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SimpleWorkflowSpec.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SimpleWorkflowSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/StartWorkflowSpec.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/StartWorkflowSpec.groovy index 0752a2b43..1af9f2f85 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/StartWorkflowSpec.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/StartWorkflowSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SubWorkflowRerunSpec.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SubWorkflowRerunSpec.groovy index c6367a957..350a896f2 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SubWorkflowRerunSpec.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SubWorkflowRerunSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SubWorkflowRestartSpec.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SubWorkflowRestartSpec.groovy index 550c225d6..519d01a18 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SubWorkflowRestartSpec.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SubWorkflowRestartSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SubWorkflowRetrySpec.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SubWorkflowRetrySpec.groovy index 0445a4777..4cab35a5a 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SubWorkflowRetrySpec.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SubWorkflowRetrySpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SubWorkflowSpec.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SubWorkflowSpec.groovy index 0a74d88ff..8bc6bbff9 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SubWorkflowSpec.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SubWorkflowSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SwitchTaskSpec.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SwitchTaskSpec.groovy index cffc9b615..93c1e6c01 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SwitchTaskSpec.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SwitchTaskSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SystemTaskSpec.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SystemTaskSpec.groovy index 926a1ded4..28bfca59b 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SystemTaskSpec.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/SystemTaskSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/TaskLimitsWorkflowSpec.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/TaskLimitsWorkflowSpec.groovy index 0211821d1..f1bcd4dec 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/TaskLimitsWorkflowSpec.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/TaskLimitsWorkflowSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/TestWorkflowSpec.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/TestWorkflowSpec.groovy index fea312fa0..374fd4c95 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/TestWorkflowSpec.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/TestWorkflowSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/WaitTaskSpec.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/WaitTaskSpec.groovy index 9a22b20fb..d00577ccd 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/WaitTaskSpec.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/WaitTaskSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/WorkflowAndTaskConfigurationSpec.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/WorkflowAndTaskConfigurationSpec.groovy index 0fbf0ec0b..3561665be 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/integration/WorkflowAndTaskConfigurationSpec.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/integration/WorkflowAndTaskConfigurationSpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/resiliency/QueueResiliencySpec.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/resiliency/QueueResiliencySpec.groovy index 44f7ade06..0149352bd 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/resiliency/QueueResiliencySpec.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/resiliency/QueueResiliencySpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/resiliency/TaskResiliencySpec.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/resiliency/TaskResiliencySpec.groovy index 45f26e5ae..4695d6587 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/resiliency/TaskResiliencySpec.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/resiliency/TaskResiliencySpec.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/groovy/com/netflix/conductor/test/util/WorkflowTestUtil.groovy b/test-harness/src/test/groovy/com/netflix/conductor/test/util/WorkflowTestUtil.groovy index 4f13a99df..52228eb47 100644 --- a/test-harness/src/test/groovy/com/netflix/conductor/test/util/WorkflowTestUtil.groovy +++ b/test-harness/src/test/groovy/com/netflix/conductor/test/util/WorkflowTestUtil.groovy @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/java/com/netflix/conductor/ConductorTestApp.java b/test-harness/src/test/java/com/netflix/conductor/ConductorTestApp.java index 51cbc9ac5..1979fc543 100644 --- a/test-harness/src/test/java/com/netflix/conductor/ConductorTestApp.java +++ b/test-harness/src/test/java/com/netflix/conductor/ConductorTestApp.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/java/com/netflix/conductor/test/integration/AbstractEndToEndTest.java b/test-harness/src/test/java/com/netflix/conductor/test/integration/AbstractEndToEndTest.java index 150e59947..c110e6730 100644 --- a/test-harness/src/test/java/com/netflix/conductor/test/integration/AbstractEndToEndTest.java +++ b/test-harness/src/test/java/com/netflix/conductor/test/integration/AbstractEndToEndTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/java/com/netflix/conductor/test/integration/grpc/AbstractGrpcEndToEndTest.java b/test-harness/src/test/java/com/netflix/conductor/test/integration/grpc/AbstractGrpcEndToEndTest.java index 3d4a23e1d..96ea7783f 100644 --- a/test-harness/src/test/java/com/netflix/conductor/test/integration/grpc/AbstractGrpcEndToEndTest.java +++ b/test-harness/src/test/java/com/netflix/conductor/test/integration/grpc/AbstractGrpcEndToEndTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/java/com/netflix/conductor/test/integration/grpc/GrpcEndToEndTest.java b/test-harness/src/test/java/com/netflix/conductor/test/integration/grpc/GrpcEndToEndTest.java index 0353cd048..fb10a2611 100644 --- a/test-harness/src/test/java/com/netflix/conductor/test/integration/grpc/GrpcEndToEndTest.java +++ b/test-harness/src/test/java/com/netflix/conductor/test/integration/grpc/GrpcEndToEndTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/java/com/netflix/conductor/test/integration/http/AbstractHttpEndToEndTest.java b/test-harness/src/test/java/com/netflix/conductor/test/integration/http/AbstractHttpEndToEndTest.java index e04a2a991..b57066c01 100644 --- a/test-harness/src/test/java/com/netflix/conductor/test/integration/http/AbstractHttpEndToEndTest.java +++ b/test-harness/src/test/java/com/netflix/conductor/test/integration/http/AbstractHttpEndToEndTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2020 Netflix, Inc. + * Copyright 2020 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/java/com/netflix/conductor/test/integration/http/HttpEndToEndTest.java b/test-harness/src/test/java/com/netflix/conductor/test/integration/http/HttpEndToEndTest.java index 0dded2cdd..e807f37cf 100644 --- a/test-harness/src/test/java/com/netflix/conductor/test/integration/http/HttpEndToEndTest.java +++ b/test-harness/src/test/java/com/netflix/conductor/test/integration/http/HttpEndToEndTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/java/com/netflix/conductor/test/utils/MockExternalPayloadStorage.java b/test-harness/src/test/java/com/netflix/conductor/test/utils/MockExternalPayloadStorage.java index f93baf6d2..18efe513e 100644 --- a/test-harness/src/test/java/com/netflix/conductor/test/utils/MockExternalPayloadStorage.java +++ b/test-harness/src/test/java/com/netflix/conductor/test/utils/MockExternalPayloadStorage.java @@ -1,5 +1,5 @@ /* - * Copyright 2021 Netflix, Inc. + * Copyright 2021 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-harness/src/test/java/com/netflix/conductor/test/utils/UserTask.java b/test-harness/src/test/java/com/netflix/conductor/test/utils/UserTask.java index d0af23206..ae1fc9ac9 100644 --- a/test-harness/src/test/java/com/netflix/conductor/test/utils/UserTask.java +++ b/test-harness/src/test/java/com/netflix/conductor/test/utils/UserTask.java @@ -1,5 +1,5 @@ /* - * Copyright 2022 Netflix, Inc. + * Copyright 2022 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-util/src/test/java/com/netflix/conductor/ConductorTestApp.java b/test-util/src/test/java/com/netflix/conductor/ConductorTestApp.java index 8a86d2fa0..b7523573d 100644 --- a/test-util/src/test/java/com/netflix/conductor/ConductorTestApp.java +++ b/test-util/src/test/java/com/netflix/conductor/ConductorTestApp.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-util/src/test/java/com/netflix/conductor/common/config/TestObjectMapperConfiguration.java b/test-util/src/test/java/com/netflix/conductor/common/config/TestObjectMapperConfiguration.java index 59f91c41b..76e6e6dab 100644 --- a/test-util/src/test/java/com/netflix/conductor/common/config/TestObjectMapperConfiguration.java +++ b/test-util/src/test/java/com/netflix/conductor/common/config/TestObjectMapperConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-util/src/test/java/com/netflix/conductor/test/integration/AbstractEndToEndTest.java b/test-util/src/test/java/com/netflix/conductor/test/integration/AbstractEndToEndTest.java index 59702412b..4065241a5 100644 --- a/test-util/src/test/java/com/netflix/conductor/test/integration/AbstractEndToEndTest.java +++ b/test-util/src/test/java/com/netflix/conductor/test/integration/AbstractEndToEndTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/test-util/src/test/java/com/netflix/conductor/test/integration/grpc/AbstractGrpcEndToEndTest.java b/test-util/src/test/java/com/netflix/conductor/test/integration/grpc/AbstractGrpcEndToEndTest.java index f66cfa3cd..5f53592bb 100644 --- a/test-util/src/test/java/com/netflix/conductor/test/integration/grpc/AbstractGrpcEndToEndTest.java +++ b/test-util/src/test/java/com/netflix/conductor/test/integration/grpc/AbstractGrpcEndToEndTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/workflow-event-listener/src/main/java/com/netflix/conductor/contribs/listener/archive/ArchivingWithTTLWorkflowStatusListener.java b/workflow-event-listener/src/main/java/com/netflix/conductor/contribs/listener/archive/ArchivingWithTTLWorkflowStatusListener.java index cc58948c1..b80ebf98f 100644 --- a/workflow-event-listener/src/main/java/com/netflix/conductor/contribs/listener/archive/ArchivingWithTTLWorkflowStatusListener.java +++ b/workflow-event-listener/src/main/java/com/netflix/conductor/contribs/listener/archive/ArchivingWithTTLWorkflowStatusListener.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/workflow-event-listener/src/main/java/com/netflix/conductor/contribs/listener/archive/ArchivingWorkflowListenerConfiguration.java b/workflow-event-listener/src/main/java/com/netflix/conductor/contribs/listener/archive/ArchivingWorkflowListenerConfiguration.java index 50978417d..d468ba960 100644 --- a/workflow-event-listener/src/main/java/com/netflix/conductor/contribs/listener/archive/ArchivingWorkflowListenerConfiguration.java +++ b/workflow-event-listener/src/main/java/com/netflix/conductor/contribs/listener/archive/ArchivingWorkflowListenerConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/workflow-event-listener/src/main/java/com/netflix/conductor/contribs/listener/archive/ArchivingWorkflowListenerProperties.java b/workflow-event-listener/src/main/java/com/netflix/conductor/contribs/listener/archive/ArchivingWorkflowListenerProperties.java index 53361429a..7e2fad5cb 100644 --- a/workflow-event-listener/src/main/java/com/netflix/conductor/contribs/listener/archive/ArchivingWorkflowListenerProperties.java +++ b/workflow-event-listener/src/main/java/com/netflix/conductor/contribs/listener/archive/ArchivingWorkflowListenerProperties.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/workflow-event-listener/src/main/java/com/netflix/conductor/contribs/listener/archive/ArchivingWorkflowStatusListener.java b/workflow-event-listener/src/main/java/com/netflix/conductor/contribs/listener/archive/ArchivingWorkflowStatusListener.java index c784c38a4..26dfdf364 100644 --- a/workflow-event-listener/src/main/java/com/netflix/conductor/contribs/listener/archive/ArchivingWorkflowStatusListener.java +++ b/workflow-event-listener/src/main/java/com/netflix/conductor/contribs/listener/archive/ArchivingWorkflowStatusListener.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/workflow-event-listener/src/main/java/com/netflix/conductor/contribs/listener/conductorqueue/ConductorQueueStatusPublisher.java b/workflow-event-listener/src/main/java/com/netflix/conductor/contribs/listener/conductorqueue/ConductorQueueStatusPublisher.java index d10bf5f73..6c0812061 100644 --- a/workflow-event-listener/src/main/java/com/netflix/conductor/contribs/listener/conductorqueue/ConductorQueueStatusPublisher.java +++ b/workflow-event-listener/src/main/java/com/netflix/conductor/contribs/listener/conductorqueue/ConductorQueueStatusPublisher.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/workflow-event-listener/src/main/java/com/netflix/conductor/contribs/listener/conductorqueue/ConductorQueueStatusPublisherConfiguration.java b/workflow-event-listener/src/main/java/com/netflix/conductor/contribs/listener/conductorqueue/ConductorQueueStatusPublisherConfiguration.java index 8cdf76f14..e0c767978 100644 --- a/workflow-event-listener/src/main/java/com/netflix/conductor/contribs/listener/conductorqueue/ConductorQueueStatusPublisherConfiguration.java +++ b/workflow-event-listener/src/main/java/com/netflix/conductor/contribs/listener/conductorqueue/ConductorQueueStatusPublisherConfiguration.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/workflow-event-listener/src/main/java/com/netflix/conductor/contribs/listener/conductorqueue/ConductorQueueStatusPublisherProperties.java b/workflow-event-listener/src/main/java/com/netflix/conductor/contribs/listener/conductorqueue/ConductorQueueStatusPublisherProperties.java index 4073ce7ad..d7e50a5a3 100644 --- a/workflow-event-listener/src/main/java/com/netflix/conductor/contribs/listener/conductorqueue/ConductorQueueStatusPublisherProperties.java +++ b/workflow-event-listener/src/main/java/com/netflix/conductor/contribs/listener/conductorqueue/ConductorQueueStatusPublisherProperties.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/workflow-event-listener/src/test/java/com/netflix/conductor/contribs/listener/ArchivingWorkflowStatusListenerTest.java b/workflow-event-listener/src/test/java/com/netflix/conductor/contribs/listener/ArchivingWorkflowStatusListenerTest.java index 7532fb01d..a3839bca5 100644 --- a/workflow-event-listener/src/test/java/com/netflix/conductor/contribs/listener/ArchivingWorkflowStatusListenerTest.java +++ b/workflow-event-listener/src/test/java/com/netflix/conductor/contribs/listener/ArchivingWorkflowStatusListenerTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at diff --git a/workflow-event-listener/src/test/java/com/netflix/conductor/test/listener/WorkflowStatusPublisherIntegrationTest.java b/workflow-event-listener/src/test/java/com/netflix/conductor/test/listener/WorkflowStatusPublisherIntegrationTest.java index 4f9f002b6..3aa8b072b 100644 --- a/workflow-event-listener/src/test/java/com/netflix/conductor/test/listener/WorkflowStatusPublisherIntegrationTest.java +++ b/workflow-event-listener/src/test/java/com/netflix/conductor/test/listener/WorkflowStatusPublisherIntegrationTest.java @@ -1,5 +1,5 @@ /* - * Copyright 2023 Netflix, Inc. + * Copyright 2023 Conductor Authors. *
* Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with * the License. You may obtain a copy of the License at