From b06b08868f16c855d0d86945e8167a2a35449c6c Mon Sep 17 00:00:00 2001 From: Andrew Thornton Date: Fri, 11 Feb 2022 11:16:03 +0000 Subject: [PATCH 01/15] Ensure that conflict status is reset if there are no conflicts The ConflictedFiles status should always be reset if there are no conflicts this prevents conflicted files being left over. Fix #17204 Signed-off-by: Andrew Thornton --- services/pull/patch.go | 4 +++- 1 file changed, 3 insertions(+), 1 deletion(-) diff --git a/services/pull/patch.go b/services/pull/patch.go index a2c8345326f0b..f7eb23f28435c 100644 --- a/services/pull/patch.go +++ b/services/pull/patch.go @@ -287,10 +287,12 @@ func checkConflicts(ctx context.Context, pr *models.PullRequest, gitRepo *git.Re if err != nil { return false, err } + pr.Status = models.PullRequestStatusMergeable + pr.ConflictedFiles = []string{} + if treeHash == baseTree.ID.String() { log.Debug("PullRequest[%d]: Patch is empty - ignoring", pr.ID) pr.Status = models.PullRequestStatusEmpty - pr.ConflictedFiles = []string{} pr.ChangedProtectedFiles = []string{} } From db1931c396e51753b7c34b46b8fa40fd5065e8c0 Mon Sep 17 00:00:00 2001 From: Andrew Thornton Date: Fri, 11 Feb 2022 12:09:31 +0000 Subject: [PATCH 02/15] Add some more trace and debug logging to process and testpatch Given the repeated issues here I've just added some plain trace logging which should allow for easier tracing of when processes are created. Signed-off-by: Andrew Thornton --- modules/process/manager.go | 4 ++++ modules/queue/workerpool.go | 10 +++++----- services/pull/check.go | 8 ++++++++ services/pull/patch.go | 2 ++ 4 files changed, 19 insertions(+), 5 deletions(-) diff --git a/modules/process/manager.go b/modules/process/manager.go index d9d2f8c3e5f9c..46c3daa2c1d92 100644 --- a/modules/process/manager.go +++ b/modules/process/manager.go @@ -15,6 +15,8 @@ import ( "strconv" "sync" "time" + + "code.gitea.io/gitea/modules/log" ) // TODO: This packages still uses a singleton for the Manager. @@ -103,6 +105,7 @@ func (pm *Manager) AddContextTimeout(parent context.Context, timeout time.Durati func (pm *Manager) Add(parentPID IDType, description string, cancel context.CancelFunc) (IDType, FinishedFunc) { pm.mutex.Lock() start, pid := pm.nextPID() + log.Trace("Adding Process[%s:%s] %s", parentPID, pid, description) parent := pm.processes[parentPID] if parent == nil { @@ -120,6 +123,7 @@ func (pm *Manager) Add(parentPID IDType, description string, cancel context.Canc finished := func() { cancel() pm.remove(process) + log.Trace("Finished Process[%d:%d] %s", parentPID, pid, description) } if parent != nil { diff --git a/modules/queue/workerpool.go b/modules/queue/workerpool.go index 100197c5e1f1f..09316b9dffdf5 100644 --- a/modules/queue/workerpool.go +++ b/modules/queue/workerpool.go @@ -484,7 +484,7 @@ func (p *WorkerPool) doWork(ctx context.Context) { case <-paused: log.Trace("Worker for Queue %d Pausing", p.qid) if len(data) > 0 { - log.Trace("Handling: %d data, %v", len(data), data) + log.Trace("Queue[%d] Handling: %d data, %v", p.qid, len(data), data) if unhandled := p.handle(data...); unhandled != nil { log.Error("Unhandled Data in queue %d", p.qid) } @@ -507,7 +507,7 @@ func (p *WorkerPool) doWork(ctx context.Context) { // go back around case <-ctx.Done(): if len(data) > 0 { - log.Trace("Handling: %d data, %v", len(data), data) + log.Trace("Queue[%d] Handling: %d data, %v", p.qid, len(data), data) if unhandled := p.handle(data...); unhandled != nil { log.Error("Unhandled Data in queue %d", p.qid) } @@ -519,7 +519,7 @@ func (p *WorkerPool) doWork(ctx context.Context) { if !ok { // the dataChan has been closed - we should finish up: if len(data) > 0 { - log.Trace("Handling: %d data, %v", len(data), data) + log.Trace("Queue[%d] Handling: %d data, %v", p.qid, len(data), data) if unhandled := p.handle(data...); unhandled != nil { log.Error("Unhandled Data in queue %d", p.qid) } @@ -532,7 +532,7 @@ func (p *WorkerPool) doWork(ctx context.Context) { util.StopTimer(timer) if len(data) >= p.batchLength { - log.Trace("Handling: %d data, %v", len(data), data) + log.Trace("Queue[%d] Handling: %d data, %v", p.qid, len(data), data) if unhandled := p.handle(data...); unhandled != nil { log.Error("Unhandled Data in queue %d", p.qid) } @@ -544,7 +544,7 @@ func (p *WorkerPool) doWork(ctx context.Context) { case <-timer.C: delay = time.Millisecond * 100 if len(data) > 0 { - log.Trace("Handling: %d data, %v", len(data), data) + log.Trace("Queue[%d] Handling: %d data, %v", p.qid, len(data), data) if unhandled := p.handle(data...); unhandled != nil { log.Error("Unhandled Data in queue %d", p.qid) } diff --git a/services/pull/check.go b/services/pull/check.go index b1e9237d11c4c..d3da2bd7f9fd1 100644 --- a/services/pull/check.go +++ b/services/pull/check.go @@ -62,9 +62,12 @@ func checkAndUpdateStatus(pr *models.PullRequest) { } if !has { + log.Trace("Updating PR[%d] in %d: Status:%d Conflicts:%s Protected:%s", pr.ID, pr.BaseRepoID, pr.Status, pr.ConflictedFiles, pr.ChangedProtectedFiles) if err := pr.UpdateColsIfNotMerged("merge_base", "status", "conflicted_files", "changed_protected_files"); err != nil { log.Error("Update[%d]: %v", pr.ID, err) } + } else { + log.Trace("Not updating PR[%d] in %d as still in the queue", pr.ID, pr.BaseRepoID) } } @@ -234,12 +237,15 @@ func testPR(id int64) { log.Error("GetPullRequestByID[%d]: %v", id, err) return } + log.Trace("Testing PR[%d] in %d", pr.ID, pr.BaseRepoID) if pr.HasMerged { + log.Trace("PR[%d] in %d: already merged", pr.ID, pr.BaseRepoID) return } if manuallyMerged(ctx, pr) { + log.Trace("PR[%d] in %d: manually merged", pr.ID, pr.BaseRepoID) return } @@ -251,6 +257,8 @@ func testPR(id int64) { } return } + log.Trace("PR[%d] in %d: patch tested new Status:%d ConflictedFiles:%s ChangedProtectedFiles:%s", pr.ID, pr.BaseRepoID, pr.Status, pr.ConflictedFiles, pr.ChangedProtectedFiles) + checkAndUpdateStatus(pr) } diff --git a/services/pull/patch.go b/services/pull/patch.go index f7eb23f28435c..e01349fcbbd22 100644 --- a/services/pull/patch.go +++ b/services/pull/patch.go @@ -280,11 +280,13 @@ func checkConflicts(ctx context.Context, pr *models.PullRequest, gitRepo *git.Re if !conflict { treeHash, err := git.NewCommand(ctx, "write-tree").RunInDir(tmpBasePath) if err != nil { + log.Debug("Unable to write unconflicted tree for PR[%d] %s/%s#%d. Error: %v", pr.ID, pr.BaseRepo.OwnerName, pr.BaseRepo.Name, pr.Index, err) return false, err } treeHash = strings.TrimSpace(treeHash) baseTree, err := gitRepo.GetTree("base") if err != nil { + log.Debug("Unable to get base tree for PR[%d] %s/%s#%d. Error: %v", pr.ID, pr.BaseRepo.OwnerName, pr.BaseRepo.Name, pr.Index, err) return false, err } pr.Status = models.PullRequestStatusMergeable From bd066ca6f36ba474a3374fc641cee315cbc0bdb5 Mon Sep 17 00:00:00 2001 From: Andrew Thornton Date: Fri, 11 Feb 2022 20:54:55 +0000 Subject: [PATCH 03/15] Add doctor commands for looking at the level DB Signed-off-by: Andrew Thornton --- modules/doctor/queue.go | 216 ++++++++++++++++++++++++++++++++++++++++ 1 file changed, 216 insertions(+) create mode 100644 modules/doctor/queue.go diff --git a/modules/doctor/queue.go b/modules/doctor/queue.go new file mode 100644 index 0000000000000..4dfe72e0fee90 --- /dev/null +++ b/modules/doctor/queue.go @@ -0,0 +1,216 @@ +// Copyright 2022 The Gitea Authors. All rights reserved. +// Use of this source code is governed by a MIT-style +// license that can be found in the LICENSE file. + +package doctor + +import ( + "context" + + "code.gitea.io/gitea/modules/log" + "code.gitea.io/gitea/modules/nosql" + "code.gitea.io/gitea/modules/queue" + "code.gitea.io/gitea/modules/setting" + "gitea.com/lunny/levelqueue" +) + +var uniqueQueueNames = []string{ + "code_indexer", + "repo_stats_update", + "mirror", + "pr_patch_checker", + "repo-archive", +} + +var queueNames = []string{ + "issue_indexer", + "notification-service", + "mail", + "push_update", + "task", +} + +var levelqueueTypes = []string{ + string(queue.PersistableChannelQueueType), + string(queue.PersistableChannelUniqueQueueType), + string(queue.LevelQueueType), + string(queue.LevelUniqueQueueType), +} + +func checkUniqueQueues(ctx context.Context, logger log.Logger, autofix bool) error { + for _, name := range uniqueQueueNames { + q := setting.GetQueueSettings(name) + if q.Type == "" { + q.Type = string(queue.PersistableChannelQueueType) + } + found := false + for _, typ := range levelqueueTypes { + if typ == q.Type { + found = true + break + } + } + if !found { + logger.Info("Queue: %s\nType: %s\nNo LevelDB", q.Name, q.Type) + continue + } + + connection := q.ConnectionString + if connection == "" { + connection = q.DataDir + } + + db, err := nosql.GetManager().GetLevelDB(connection) + if err != nil { + logger.Error("Queue: %s\nUnable to open DB connection %s: %v", q.Name, connection, err) + return err + } + defer db.Close() + + prefix := q.Name + + iQueue, err := levelqueue.NewQueue(db, []byte(prefix), false) + if err != nil { + logger.Error("Queue: %s\nUnable to open Queue component: %v", q.Name, err) + return err + } + + iSet, err := levelqueue.NewSet(db, []byte(prefix+"-unique"), false) + if err != nil { + logger.Error("Queue: %s\nUnable to open Set component: %v", q.Name, err) + return err + } + + qLen := iQueue.Len() + sMembers, err := iSet.Members() + if err != nil { + logger.Error("Queue: %s\nUnable to get members of Set component: %v", q.Name, err) + return err + } + sLen := len(sMembers) + + if int(qLen) == sLen { + if qLen == 0 { + logger.Info("Queue: %s\nType: %s\nLevelDB: %s", q.Name, q.Type, "empty") + } else { + logger.Info("Queue: %s\nType: %s\nLevelDB contains: %d entries", q.Name, q.Type, qLen) + } + continue + } + logger.Warn("Queue: %s\nType: %s\nContains different numbers of elements in Queue component %d to Set component %d", q.Name, q.Type, qLen, sLen) + if !autofix { + continue + } + + // Empty out the old set members + for _, member := range sMembers { + _, err := iSet.Remove(member) + if err != nil { + logger.Error("Queue: %s\nUnable to remove Set member %s: %v", q.Name, string(member), err) + return err + } + } + + // Now iterate across the queue + for i := int64(0); i < qLen; i++ { + // Pop from the left + qData, err := iQueue.LPop() + if err != nil { + logger.Error("Queue: %s\nUnable to LPop out: %v", q.Name, err) + return err + } + // And add to the right + err = iQueue.RPush(qData) + if err != nil { + logger.Error("Queue: %s\nUnable to RPush back: %v", q.Name, err) + return err + } + // And add back to the set + _, err = iSet.Add(qData) + if err != nil { + logger.Error("Queue: %s\nUnable to add back in to Set: %v", q.Name, err) + return err + } + } + } + return nil +} + +func queueListDB(ctx context.Context, logger log.Logger, autofix bool) error { + connections := []string{} + + for _, name := range append(uniqueQueueNames, queueNames...) { + q := setting.GetQueueSettings(name) + if q.Type == "" { + q.Type = string(queue.PersistableChannelQueueType) + } + found := false + for _, typ := range levelqueueTypes { + if typ == q.Type { + found = true + break + } + } + if !found { + continue + } + if q.ConnectionString != "" { + found := false + for _, connection := range connections { + if connection == q.ConnectionString { + found = true + } + } + if !found { + connections = append(connections, q.ConnectionString) + } + continue + } + found = false + for _, connection := range connections { + if connection == q.DataDir { + found = true + } + } + if !found { + connections = append(connections, q.DataDir) + } + } + + for _, connection := range connections { + logger.Info("LevelDB: %s", connection) + db, err := nosql.GetManager().GetLevelDB(connection) + if err != nil { + logger.Error("Connection: %s Unable to open DB: %v", connection, err) + return err + } + defer db.Close() + iter := db.NewIterator(nil, nil) + for iter.Next() { + logger.Info("%s\n%s", log.NewColoredIDValue(string(iter.Key())), string(iter.Value())) + } + iter.Release() + } + return nil +} + +func init() { + Register(&Check{ + Title: "Check if there are corrupt level uniquequeues", + Name: "uniquequeues-corrupt", + IsDefault: false, + Run: checkUniqueQueues, + AbortIfFailed: false, + SkipDatabaseInitialization: false, + Priority: 1, + }) + Register(&Check{ + Title: "List all entries in leveldb", + Name: "queues-listdb", + IsDefault: false, + Run: queueListDB, + AbortIfFailed: false, + SkipDatabaseInitialization: false, + Priority: 1, + }) +} From 1475c62b299bb682c6a8bce2c2b2be2341cc6b4b Mon Sep 17 00:00:00 2001 From: Andrew Thornton Date: Sun, 13 Feb 2022 14:46:42 +0000 Subject: [PATCH 04/15] As per review Signed-off-by: Andrew Thornton --- modules/doctor/queue.go | 36 +++++------- modules/indexer/code/indexer.go | 2 +- modules/indexer/issues/indexer.go | 2 +- modules/indexer/stats/queue.go | 4 +- modules/notification/ui/ui.go | 2 +- modules/queue/setting.go | 75 ++++++++++++++++++++++-- services/mailer/mailer.go | 2 +- services/mirror/mirror.go | 2 +- services/pull/check.go | 4 +- services/repository/archiver/archiver.go | 4 +- services/repository/push.go | 2 +- services/task/task.go | 6 +- 12 files changed, 100 insertions(+), 41 deletions(-) diff --git a/modules/doctor/queue.go b/modules/doctor/queue.go index 4dfe72e0fee90..add8ce3d10938 100644 --- a/modules/doctor/queue.go +++ b/modules/doctor/queue.go @@ -14,22 +14,6 @@ import ( "gitea.com/lunny/levelqueue" ) -var uniqueQueueNames = []string{ - "code_indexer", - "repo_stats_update", - "mirror", - "pr_patch_checker", - "repo-archive", -} - -var queueNames = []string{ - "issue_indexer", - "notification-service", - "mail", - "push_update", - "task", -} - var levelqueueTypes = []string{ string(queue.PersistableChannelQueueType), string(queue.PersistableChannelUniqueQueueType), @@ -38,8 +22,8 @@ var levelqueueTypes = []string{ } func checkUniqueQueues(ctx context.Context, logger log.Logger, autofix bool) error { - for _, name := range uniqueQueueNames { - q := setting.GetQueueSettings(name) + for _, name := range queue.KnownUniqueQueueNames { + q := setting.GetQueueSettings(string(name)) if q.Type == "" { q.Type = string(queue.PersistableChannelQueueType) } @@ -62,7 +46,7 @@ func checkUniqueQueues(ctx context.Context, logger log.Logger, autofix bool) err db, err := nosql.GetManager().GetLevelDB(connection) if err != nil { - logger.Error("Queue: %s\nUnable to open DB connection %s: %v", q.Name, connection, err) + logger.Error("Queue: %s\nUnable to open DB connection %q: %v", q.Name, connection, err) return err } defer db.Close() @@ -138,8 +122,15 @@ func checkUniqueQueues(ctx context.Context, logger log.Logger, autofix bool) err func queueListDB(ctx context.Context, logger log.Logger, autofix bool) error { connections := []string{} + queueNames := make([]string, 0, len(queue.KnownUniqueQueueNames)+len(queue.KnownQueueNames)) + for _, name := range queue.KnownUniqueQueueNames { + queueNames = append(queueNames, string(name)) + } + for _, name := range queue.KnownQueueNames { + queueNames = append(queueNames, string(name)) + } - for _, name := range append(uniqueQueueNames, queueNames...) { + for _, name := range queueNames { q := setting.GetQueueSettings(name) if q.Type == "" { q.Type = string(queue.PersistableChannelQueueType) @@ -159,6 +150,7 @@ func queueListDB(ctx context.Context, logger log.Logger, autofix bool) error { for _, connection := range connections { if connection == q.ConnectionString { found = true + break } } if !found { @@ -170,6 +162,7 @@ func queueListDB(ctx context.Context, logger log.Logger, autofix bool) error { for _, connection := range connections { if connection == q.DataDir { found = true + break } } if !found { @@ -181,7 +174,7 @@ func queueListDB(ctx context.Context, logger log.Logger, autofix bool) error { logger.Info("LevelDB: %s", connection) db, err := nosql.GetManager().GetLevelDB(connection) if err != nil { - logger.Error("Connection: %s Unable to open DB: %v", connection, err) + logger.Error("Connection: %q Unable to open DB: %v", connection, err) return err } defer db.Close() @@ -204,6 +197,7 @@ func init() { SkipDatabaseInitialization: false, Priority: 1, }) + Register(&Check{ Title: "List all entries in leveldb", Name: "queues-listdb", diff --git a/modules/indexer/code/indexer.go b/modules/indexer/code/indexer.go index d897fcccd5489..187c16cd27eaa 100644 --- a/modules/indexer/code/indexer.go +++ b/modules/indexer/code/indexer.go @@ -163,7 +163,7 @@ func Init() { return unhandled } - indexerQueue = queue.CreateUniqueQueue("code_indexer", handler, &IndexerData{}) + indexerQueue = queue.CreateUniqueQueue(queue.CodeIndexerQueueName, handler, &IndexerData{}) if indexerQueue == nil { log.Fatal("Unable to create codes indexer queue") } diff --git a/modules/indexer/issues/indexer.go b/modules/indexer/issues/indexer.go index 3aaa27eed213b..44249326c0b46 100644 --- a/modules/indexer/issues/indexer.go +++ b/modules/indexer/issues/indexer.go @@ -154,7 +154,7 @@ func InitIssueIndexer(syncReindex bool) { return nil } - issueIndexerQueue = queue.CreateQueue("issue_indexer", handler, &IndexerData{}) + issueIndexerQueue = queue.CreateQueue(queue.IssueIndexerQueueName, handler, &IndexerData{}) if issueIndexerQueue == nil { log.Fatal("Unable to create issue indexer queue") diff --git a/modules/indexer/stats/queue.go b/modules/indexer/stats/queue.go index f983fcd11d563..68a74d4bb2c8a 100644 --- a/modules/indexer/stats/queue.go +++ b/modules/indexer/stats/queue.go @@ -28,9 +28,9 @@ func handle(data ...queue.Data) []queue.Data { } func initStatsQueue() error { - statsQueue = queue.CreateUniqueQueue("repo_stats_update", handle, int64(0)) + statsQueue = queue.CreateUniqueQueue(queue.RepoStatsUpdateQueueName, handle, int64(0)) if statsQueue == nil { - return fmt.Errorf("Unable to create repo_stats_update Queue") + return fmt.Errorf("unable to create repo_stats_update Queue") } go graceful.GetManager().RunWithShutdownFns(statsQueue.Run) diff --git a/modules/notification/ui/ui.go b/modules/notification/ui/ui.go index a27c5f699cbc5..83530a243f9e4 100644 --- a/modules/notification/ui/ui.go +++ b/modules/notification/ui/ui.go @@ -34,7 +34,7 @@ var _ base.Notifier = ¬ificationService{} // NewNotifier create a new notificationService notifier func NewNotifier() base.Notifier { ns := ¬ificationService{} - ns.issueQueue = queue.CreateQueue("notification-service", ns.handle, issueNotificationOpts{}) + ns.issueQueue = queue.CreateQueue(queue.NotificationQueueName, ns.handle, issueNotificationOpts{}) return ns } diff --git a/modules/queue/setting.go b/modules/queue/setting.go index 880770f073957..739d9e7260c8e 100644 --- a/modules/queue/setting.go +++ b/modules/queue/setting.go @@ -13,6 +13,48 @@ import ( "code.gitea.io/gitea/modules/setting" ) +// UniqueQueueName represents an expected name for an UniqueQueue +type UniqueQueueName string + +// list of all expected UniqueQueues +const ( + CodeIndexerQueueName UniqueQueueName = "code_indexer" + RepoStatsUpdateQueueName UniqueQueueName = "repo_stats_update" + MirrorQueueName UniqueQueueName = "mirror" + PRPatchQueueName UniqueQueueName = "pr_patch_checker" + RepoArchiveQueueName UniqueQueueName = "repo-archive" +) + +// KnownUniqueQueueNames represents the list of expected unique queues +var KnownUniqueQueueNames = []UniqueQueueName{ + CodeIndexerQueueName, + RepoStatsUpdateQueueName, + MirrorQueueName, + PRPatchQueueName, + RepoArchiveQueueName, +} + +// QueueName represents an expected name for Queue +type QueueName string + +// list of all expected Queues +const ( + IssueIndexerQueueName QueueName = "issue_indexer" + NotificationQueueName QueueName = "notification-service" + MailerQueueName QueueName = "mail" + PushUpdateQueueName QueueName = "push_update" + TaskQueueName QueueName = "task" +) + +// KnownQueueNames represents the list of expected queues +var KnownQueueNames = []QueueName{ + IssueIndexerQueueName, + NotificationQueueName, + MailerQueueName, + PushUpdateQueueName, + TaskQueueName, +} + func validType(t string) (Type, error) { if len(t) == 0 { return PersistableChannelQueueType, nil @@ -37,8 +79,19 @@ func getQueueSettings(name string) (setting.QueueSettings, []byte) { } // CreateQueue for name with provided handler and exemplar -func CreateQueue(name string, handle HandlerFunc, exemplar interface{}) Queue { - q, cfg := getQueueSettings(name) +func CreateQueue(name QueueName, handle HandlerFunc, exemplar interface{}) Queue { + found := false + for _, expected := range KnownQueueNames { + if name == expected { + found = true + break + } + } + if !found { + log.Warn("%s is not an expected name for an Queue", name) + } + + q, cfg := getQueueSettings(string(name)) if len(cfg) == 0 { return nil } @@ -58,7 +111,7 @@ func CreateQueue(name string, handle HandlerFunc, exemplar interface{}) Queue { MaxAttempts: q.MaxAttempts, Config: cfg, QueueLength: q.QueueLength, - Name: name, + Name: string(name), }, exemplar) } if err != nil { @@ -79,8 +132,19 @@ func CreateQueue(name string, handle HandlerFunc, exemplar interface{}) Queue { } // CreateUniqueQueue for name with provided handler and exemplar -func CreateUniqueQueue(name string, handle HandlerFunc, exemplar interface{}) UniqueQueue { - q, cfg := getQueueSettings(name) +func CreateUniqueQueue(name UniqueQueueName, handle HandlerFunc, exemplar interface{}) UniqueQueue { + found := false + for _, expected := range KnownUniqueQueueNames { + if name == expected { + found = true + break + } + } + if !found { + log.Warn("%s is not an expected name for an UniqueQueue", name) + } + + q, cfg := getQueueSettings(string(name)) if len(cfg) == 0 { return nil } @@ -107,6 +171,7 @@ func CreateUniqueQueue(name string, handle HandlerFunc, exemplar interface{}) Un MaxAttempts: q.MaxAttempts, Config: cfg, QueueLength: q.QueueLength, + Name: string(name), }, exemplar) } if err != nil { diff --git a/services/mailer/mailer.go b/services/mailer/mailer.go index 3ca9b50fc6147..2849914d1970d 100644 --- a/services/mailer/mailer.go +++ b/services/mailer/mailer.go @@ -346,7 +346,7 @@ func NewContext() { Sender = &dummySender{} } - mailQueue = queue.CreateQueue("mail", func(data ...queue.Data) []queue.Data { + mailQueue = queue.CreateQueue(queue.MailerQueueName, func(data ...queue.Data) []queue.Data { for _, datum := range data { msg := datum.(*Message) gomailMsg := msg.ToMessage() diff --git a/services/mirror/mirror.go b/services/mirror/mirror.go index 5639a08f96401..82b92e930cb9e 100644 --- a/services/mirror/mirror.go +++ b/services/mirror/mirror.go @@ -151,7 +151,7 @@ func InitSyncMirrors() { if !setting.Mirror.Enabled { return } - mirrorQueue = queue.CreateUniqueQueue("mirror", queueHandle, new(SyncRequest)) + mirrorQueue = queue.CreateUniqueQueue(queue.MirrorQueueName, queueHandle, new(SyncRequest)) go graceful.GetManager().RunWithShutdownFns(mirrorQueue.Run) } diff --git a/services/pull/check.go b/services/pull/check.go index d3da2bd7f9fd1..0f4c9d19cdaec 100644 --- a/services/pull/check.go +++ b/services/pull/check.go @@ -278,10 +278,10 @@ func CheckPrsForBaseBranch(baseRepo *repo_model.Repository, baseBranchName strin // Init runs the task queue to test all the checking status pull requests func Init() error { - prQueue = queue.CreateUniqueQueue("pr_patch_checker", handle, "") + prQueue = queue.CreateUniqueQueue(queue.PRPatchQueueName, handle, "") if prQueue == nil { - return fmt.Errorf("Unable to create pr_patch_checker Queue") + return fmt.Errorf("unable to create pr_patch_checker Queue") } go graceful.GetManager().RunWithShutdownFns(prQueue.Run) diff --git a/services/repository/archiver/archiver.go b/services/repository/archiver/archiver.go index ad2141ef3301f..eee32fa499f15 100644 --- a/services/repository/archiver/archiver.go +++ b/services/repository/archiver/archiver.go @@ -261,9 +261,9 @@ func Init() error { return nil } - archiverQueue = queue.CreateUniqueQueue("repo-archive", handler, new(ArchiveRequest)) + archiverQueue = queue.CreateUniqueQueue(queue.RepoArchiveQueueName, handler, new(ArchiveRequest)) if archiverQueue == nil { - return errors.New("unable to create codes indexer queue") + return errors.New("unable to create repo archiver queue") } go graceful.GetManager().RunWithShutdownFns(archiverQueue.Run) diff --git a/services/repository/push.go b/services/repository/push.go index fafe4736ab4e5..031d709b5d9c0 100644 --- a/services/repository/push.go +++ b/services/repository/push.go @@ -44,7 +44,7 @@ func handle(data ...queue.Data) []queue.Data { } func initPushQueue() error { - pushQueue = queue.CreateQueue("push_update", handle, []*repo_module.PushUpdateOptions{}) + pushQueue = queue.CreateQueue(queue.PushUpdateQueueName, handle, []*repo_module.PushUpdateOptions{}) if pushQueue == nil { return errors.New("unable to create push_update Queue") } diff --git a/services/task/task.go b/services/task/task.go index 3f823fc224c8e..d24b52eb4c0f2 100644 --- a/services/task/task.go +++ b/services/task/task.go @@ -32,16 +32,16 @@ func Run(t *models.Task) error { case structs.TaskTypeMigrateRepo: return runMigrateTask(t) default: - return fmt.Errorf("Unknown task type: %d", t.Type) + return fmt.Errorf("unknown task type: %d", t.Type) } } // Init will start the service to get all unfinished tasks and run them func Init() error { - taskQueue = queue.CreateQueue("task", handle, &models.Task{}) + taskQueue = queue.CreateQueue(queue.TaskQueueName, handle, &models.Task{}) if taskQueue == nil { - return fmt.Errorf("Unable to create Task Queue") + return fmt.Errorf("unable to create Task Queue") } go graceful.GetManager().RunWithShutdownFns(taskQueue.Run) From 93d827554c2f34aa278a7894525bef5dc5227f43 Mon Sep 17 00:00:00 2001 From: Andrew Thornton Date: Sun, 13 Feb 2022 14:47:55 +0000 Subject: [PATCH 05/15] refix process manager trace ended Signed-off-by: Andrew Thornton --- modules/process/manager.go | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/modules/process/manager.go b/modules/process/manager.go index 46c3daa2c1d92..f54943d55851b 100644 --- a/modules/process/manager.go +++ b/modules/process/manager.go @@ -123,7 +123,7 @@ func (pm *Manager) Add(parentPID IDType, description string, cancel context.Canc finished := func() { cancel() pm.remove(process) - log.Trace("Finished Process[%d:%d] %s", parentPID, pid, description) + log.Trace("Finished Process[%s:%s] %s", parentPID, pid, description) } if parent != nil { From 53232c441dfdcebf11fa3ab10fa1a75b88ef520a Mon Sep 17 00:00:00 2001 From: Andrew Thornton Date: Sun, 13 Feb 2022 15:11:39 +0000 Subject: [PATCH 06/15] No revive - we want this to stutter Signed-off-by: Andrew Thornton --- modules/queue/setting.go | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/modules/queue/setting.go b/modules/queue/setting.go index 739d9e7260c8e..3c90982e918d2 100644 --- a/modules/queue/setting.go +++ b/modules/queue/setting.go @@ -35,7 +35,7 @@ var KnownUniqueQueueNames = []UniqueQueueName{ } // QueueName represents an expected name for Queue -type QueueName string +type QueueName string // nolint (allow this to stutter) // list of all expected Queues const ( From 1500a0d28afa4148b9c92108a40ecae9519ed254 Mon Sep 17 00:00:00 2001 From: zeripath Date: Sun, 27 Mar 2022 04:10:10 +0100 Subject: [PATCH 07/15] Update modules/doctor/queue.go Co-authored-by: 6543 <6543@obermui.de> --- modules/doctor/queue.go | 1 + 1 file changed, 1 insertion(+) diff --git a/modules/doctor/queue.go b/modules/doctor/queue.go index add8ce3d10938..4bc921f4ee979 100644 --- a/modules/doctor/queue.go +++ b/modules/doctor/queue.go @@ -11,6 +11,7 @@ import ( "code.gitea.io/gitea/modules/nosql" "code.gitea.io/gitea/modules/queue" "code.gitea.io/gitea/modules/setting" + "gitea.com/lunny/levelqueue" ) From a639e447ba309785b9fcbb90c5eeb26e9bdfc62a Mon Sep 17 00:00:00 2001 From: Andrew Thornton Date: Sat, 4 Jun 2022 09:58:15 +0100 Subject: [PATCH 08/15] remove trace logging from process manager Signed-off-by: Andrew Thornton --- modules/process/manager.go | 5 ----- 1 file changed, 5 deletions(-) diff --git a/modules/process/manager.go b/modules/process/manager.go index 61788364b045d..5d7aee760f58d 100644 --- a/modules/process/manager.go +++ b/modules/process/manager.go @@ -11,8 +11,6 @@ import ( "strconv" "sync" "time" - - "code.gitea.io/gitea/modules/log" ) // TODO: This packages still uses a singleton for the Manager. @@ -126,7 +124,6 @@ func (pm *Manager) Add(ctx context.Context, description string, cancel context.C pm.mutex.Lock() start, pid := pm.nextPID() - log.Trace("Adding Process[%s:%s] %s", parentPID, pid, description) parent := pm.processMap[parentPID] if parent == nil { @@ -148,13 +145,11 @@ func (pm *Manager) Add(ctx context.Context, description string, cancel context.C cancel() pm.remove(process) pprof.SetGoroutineLabels(ctx) - log.Trace("Finished Process[%s:%s] %s", parentPID, pid, description) } } else { finished = func() { cancel() pm.remove(process) - log.Trace("Finished Process[%s:%s] %s", parentPID, pid, description) } } From bd5ca046be30eb8997b25383aa615ba5fb66be89 Mon Sep 17 00:00:00 2001 From: Andrew Thornton Date: Wed, 13 Jul 2022 17:19:09 +0100 Subject: [PATCH 09/15] use constants for queues Signed-off-by: Andrew Thornton --- modules/mirror/mirror.go | 2 +- modules/queue/setting.go | 2 ++ services/automerge/automerge.go | 2 +- services/webhook/deliver.go | 2 +- 4 files changed, 5 insertions(+), 3 deletions(-) diff --git a/modules/mirror/mirror.go b/modules/mirror/mirror.go index b261bd0242634..634d5c9cb29c3 100644 --- a/modules/mirror/mirror.go +++ b/modules/mirror/mirror.go @@ -34,7 +34,7 @@ func StartSyncMirrors(queueHandle func(data ...queue.Data) []queue.Data) { if !setting.Mirror.Enabled { return } - mirrorQueue = queue.CreateUniqueQueue("mirror", queueHandle, new(SyncRequest)) + mirrorQueue = queue.CreateUniqueQueue(queue.MirrorQueueName, queueHandle, new(SyncRequest)) go graceful.GetManager().RunWithShutdownFns(mirrorQueue.Run) } diff --git a/modules/queue/setting.go b/modules/queue/setting.go index 3c90982e918d2..c6d6deff57b28 100644 --- a/modules/queue/setting.go +++ b/modules/queue/setting.go @@ -23,6 +23,8 @@ const ( MirrorQueueName UniqueQueueName = "mirror" PRPatchQueueName UniqueQueueName = "pr_patch_checker" RepoArchiveQueueName UniqueQueueName = "repo-archive" + PRAutoMergeQueueName UniqueQueueName = "pr_auto_merge" + WebhookDeliveryQueueName UniqueQueueName = "webhook_sender" ) // KnownUniqueQueueNames represents the list of expected unique queues diff --git a/services/automerge/automerge.go b/services/automerge/automerge.go index ca008ebfe6c82..8cda13e7e364e 100644 --- a/services/automerge/automerge.go +++ b/services/automerge/automerge.go @@ -30,7 +30,7 @@ var prAutoMergeQueue queue.UniqueQueue // Init runs the task queue to that handles auto merges func Init() error { - prAutoMergeQueue = queue.CreateUniqueQueue("pr_auto_merge", handle, "") + prAutoMergeQueue = queue.CreateUniqueQueue(queue.PRAutoMergeQueueName, handle, "") if prAutoMergeQueue == nil { return fmt.Errorf("Unable to create pr_auto_merge Queue") } diff --git a/services/webhook/deliver.go b/services/webhook/deliver.go index 77744473f1ce3..1b04bd3228912 100644 --- a/services/webhook/deliver.go +++ b/services/webhook/deliver.go @@ -281,7 +281,7 @@ func Init() error { }, } - hookQueue = queue.CreateUniqueQueue("webhook_sender", handle, "") + hookQueue = queue.CreateUniqueQueue(queue.WebhookDeliveryQueueName, handle, "") if hookQueue == nil { return fmt.Errorf("Unable to create webhook_sender Queue") } From 468019557ae8c7c8dcb64999578e1526aff3159e Mon Sep 17 00:00:00 2001 From: Andrew Thornton Date: Sun, 17 Jul 2022 20:54:40 +0100 Subject: [PATCH 10/15] placate linter Signed-off-by: Andrew Thornton --- modules/queue/setting.go | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/modules/queue/setting.go b/modules/queue/setting.go index c6d6deff57b28..9d49f16a88aa2 100644 --- a/modules/queue/setting.go +++ b/modules/queue/setting.go @@ -37,7 +37,7 @@ var KnownUniqueQueueNames = []UniqueQueueName{ } // QueueName represents an expected name for Queue -type QueueName string // nolint (allow this to stutter) +type QueueName string // nolint // allow this to stutter // list of all expected Queues const ( From 2e9cdfbaa12d549130605c4e108028dd82213f70 Mon Sep 17 00:00:00 2001 From: Andrew Thornton Date: Tue, 31 Jan 2023 21:37:50 +0000 Subject: [PATCH 11/15] placate the bloody linter Signed-off-by: Andrew Thornton --- modules/queue/setting.go | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/modules/queue/setting.go b/modules/queue/setting.go index 10ec9702f69d0..7e95c9b4cb3e7 100644 --- a/modules/queue/setting.go +++ b/modules/queue/setting.go @@ -36,7 +36,7 @@ var KnownUniqueQueueNames = []UniqueQueueName{ } // QueueName represents an expected name for Queue -type QueueName string // nolint // allow this to stutter +type QueueName string //nolint // allow this to stutter // list of all expected Queues const ( From ff707de46ca2dd2b5edc42f10a86f7919b2a8622 Mon Sep 17 00:00:00 2001 From: zeripath Date: Wed, 1 Feb 2023 09:37:01 +0000 Subject: [PATCH 12/15] replacate lint. --- modules/doctor/queue.go | 3 +-- 1 file changed, 1 insertion(+), 2 deletions(-) diff --git a/modules/doctor/queue.go b/modules/doctor/queue.go index 4bc921f4ee979..251906d395d67 100644 --- a/modules/doctor/queue.go +++ b/modules/doctor/queue.go @@ -1,6 +1,5 @@ // Copyright 2022 The Gitea Authors. All rights reserved. -// Use of this source code is governed by a MIT-style -// license that can be found in the LICENSE file. +// SPDX-License-Identifier: MIT package doctor From 900bb10bc373069a5fd11f3b7220628ea22d8ab3 Mon Sep 17 00:00:00 2001 From: Andrew Thornton Date: Sun, 26 Feb 2023 09:40:21 +0000 Subject: [PATCH 13/15] remove mismerged files Signed-off-by: Andrew Thornton --- options/license/AdaCore-doc | 1 - options/license/Autoconf-exception-generic | 4 - options/license/Autoconf-exception-macro | 12 - options/license/BSD-4.3RENO | 9 - options/license/BSD-4.3TAHOE | 11 - .../license/BSD-Advertising-Acknowledgement | 37 -- .../license/BSD-Attribution-HPND-disclaimer | 37 -- options/license/Brian-Gladman-3-Clause | 26 - options/license/CC-BY-NC-SA-2.0-DE | 85 ---- options/license/CFITSIO | 7 - options/license/CMU-Mach | 22 - options/license/Clips | 15 - options/license/Cornell-Lossless-JPEG | 20 - options/license/GNAT-exception | 6 - options/license/HP-1986 | 10 - options/license/HPND-Markus-Kuhn | 3 - .../license/HPND-sell-variant-MIT-disclaimer | 20 - options/license/IEC-Code-Components-EULA | 37 -- options/license/JPL-image | 21 - options/license/Kazlib | 4 - options/license/Martin-Birgmeier | 5 - options/license/OFFIS | 22 - options/license/OpenPBS-2.3 | 76 --- options/license/QPL-1.0-INRIA-2004 | 102 ---- options/license/QPL-1.0-INRIA-2004-exception | 5 - options/license/SWI-exception | 6 - options/license/SunPro | 6 - options/license/TPL-1.0 | 475 ------------------ options/license/UCAR | 32 -- options/license/snprintf | 3 - options/license/w3m | 11 - options/license/xlock | 14 - 32 files changed, 1144 deletions(-) delete mode 100644 options/license/AdaCore-doc delete mode 100644 options/license/Autoconf-exception-generic delete mode 100644 options/license/Autoconf-exception-macro delete mode 100644 options/license/BSD-4.3RENO delete mode 100644 options/license/BSD-4.3TAHOE delete mode 100644 options/license/BSD-Advertising-Acknowledgement delete mode 100644 options/license/BSD-Attribution-HPND-disclaimer delete mode 100644 options/license/Brian-Gladman-3-Clause delete mode 100644 options/license/CC-BY-NC-SA-2.0-DE delete mode 100644 options/license/CFITSIO delete mode 100644 options/license/CMU-Mach delete mode 100644 options/license/Clips delete mode 100644 options/license/Cornell-Lossless-JPEG delete mode 100644 options/license/GNAT-exception delete mode 100644 options/license/HP-1986 delete mode 100644 options/license/HPND-Markus-Kuhn delete mode 100644 options/license/HPND-sell-variant-MIT-disclaimer delete mode 100644 options/license/IEC-Code-Components-EULA delete mode 100644 options/license/JPL-image delete mode 100644 options/license/Kazlib delete mode 100644 options/license/Martin-Birgmeier delete mode 100644 options/license/OFFIS delete mode 100644 options/license/OpenPBS-2.3 delete mode 100644 options/license/QPL-1.0-INRIA-2004 delete mode 100644 options/license/QPL-1.0-INRIA-2004-exception delete mode 100644 options/license/SWI-exception delete mode 100644 options/license/SunPro delete mode 100644 options/license/TPL-1.0 delete mode 100644 options/license/UCAR delete mode 100644 options/license/snprintf delete mode 100644 options/license/w3m delete mode 100644 options/license/xlock diff --git a/options/license/AdaCore-doc b/options/license/AdaCore-doc deleted file mode 100644 index 0a1dab1b2c305..0000000000000 --- a/options/license/AdaCore-doc +++ /dev/null @@ -1 +0,0 @@ -This document may be copied, in whole or in part, in any form or by any means, as is or with alterations, provided that (1) alterations are clearly marked as alterations and (2) this copyright notice is included unmodified in any copy. diff --git a/options/license/Autoconf-exception-generic b/options/license/Autoconf-exception-generic deleted file mode 100644 index b39f82767343b..0000000000000 --- a/options/license/Autoconf-exception-generic +++ /dev/null @@ -1,4 +0,0 @@ -As a special exception to the GNU General Public License, -if you distribute this file as part of a program that contains -a configuration script generated by Autoconf, you may include -it under the same distribution terms that you use for the rest of that program. diff --git a/options/license/Autoconf-exception-macro b/options/license/Autoconf-exception-macro deleted file mode 100644 index 8b5b4677f3eb0..0000000000000 --- a/options/license/Autoconf-exception-macro +++ /dev/null @@ -1,12 +0,0 @@ -As a special exception, the respective Autoconf Macro's copyright owner -gives unlimited permission to copy, distribute and modify the configure -scripts that are the output of Autoconf when processing the Macro. You -need not follow the terms of the GNU General Public License when using -or distributing such scripts, even though portions of the text of the -Macro appear in them. The GNU General Public License (GPL) does govern -all other use of the material that constitutes the Autoconf Macro. - -This special exception to the GPL applies to versions of the Autoconf -Macro released by the Autoconf Archive. When you make and distribute a -modified version of the Autoconf Macro, you may extend this special -exception to the GPL to apply to your modified version as well. diff --git a/options/license/BSD-4.3RENO b/options/license/BSD-4.3RENO deleted file mode 100644 index c05b03cc0f693..0000000000000 --- a/options/license/BSD-4.3RENO +++ /dev/null @@ -1,9 +0,0 @@ -Copyright (c) 1987 Regents of the University of California. -All rights reserved. - -Redistribution and use in source and binary forms are permitted -provided that this notice is preserved and that due credit is given -to the University of California at Berkeley. The name of the University -may not be used to endorse or promote products derived from this -software without specific written prior permission. This software -is provided ``as is'' without express or implied warranty. diff --git a/options/license/BSD-4.3TAHOE b/options/license/BSD-4.3TAHOE deleted file mode 100644 index 413098d93c01d..0000000000000 --- a/options/license/BSD-4.3TAHOE +++ /dev/null @@ -1,11 +0,0 @@ -Copyright (c) 1987 Regents of the University of California. All rights reserved. - -Redistribution and use in source and binary forms are permitted provided -that the above copyright notice and this paragraph are duplicated in all -such forms and that any documentation, advertising materials, and other -materials related to such distribution and use acknowledge that the software -was developed by the University of California, Berkeley. The name of the -University may not be used to endorse or promote products derived from this -software without specific prior written permission. THIS SOFTWARE IS PROVIDED -``AS IS'' AND WITHOUT ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, WITHOUT -LIMITATION, THE IMPLIED WARRANTIES OF MERCHANTIBILITY AND FITNESS FOR A PARTICULAR PURPOSE. diff --git a/options/license/BSD-Advertising-Acknowledgement b/options/license/BSD-Advertising-Acknowledgement deleted file mode 100644 index cedb72e6774f4..0000000000000 --- a/options/license/BSD-Advertising-Acknowledgement +++ /dev/null @@ -1,37 +0,0 @@ -Copyright (c) 2001 David Giffin. -All rights reserved. - -Redistribution and use in source and binary forms, with or without -modification, are permitted provided that the following conditions -are met: - -1. Redistributions of source code must retain the above copyright -notice, this list of conditions and the following disclaimer. - -2. Redistributions in binary form must reproduce the above copyright -notice, this list of conditions and the following disclaimer in -the documentation and/or other materials provided with the -distribution. - -3. All advertising materials mentioning features or use of this -software must display the following acknowledgment: -"This product includes software developed by -David Giffin ." - -4. Redistributions of any form whatsoever must retain the following -acknowledgment: -"This product includes software developed by -David Giffin ." - -THIS SOFTWARE IS PROVIDED BY DAVID GIFFIN ``AS IS'' AND ANY -EXPRESSED OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE -IMPLIED WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR -PURPOSE ARE DISCLAIMED. IN NO EVENT SHALL DAVID GIFFIN OR -ITS CONTRIBUTORS BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL, -SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT -NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; -LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) -HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, -STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) -ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED -OF THE POSSIBILITY OF SUCH DAMAGE. diff --git a/options/license/BSD-Attribution-HPND-disclaimer b/options/license/BSD-Attribution-HPND-disclaimer deleted file mode 100644 index 1272e1fe26a22..0000000000000 --- a/options/license/BSD-Attribution-HPND-disclaimer +++ /dev/null @@ -1,37 +0,0 @@ -Copyright (c) 1998-2003 Carnegie Mellon University. All rights reserved. - -Redistribution and use in source and binary forms, with or without -modification, are permitted provided that the following conditions -are met: - -1. Redistributions of source code must retain the above copyright - notice, this list of conditions and the following disclaimer. - -2. Redistributions in binary form must reproduce the above copyright - notice, this list of conditions and the following disclaimer in - the documentation and/or other materials provided with the - distribution. - -3. The name "Carnegie Mellon University" must not be used to - endorse or promote products derived from this software without - prior written permission. For permission or any other legal - details, please contact - Office of Technology Transfer - Carnegie Mellon University - 5000 Forbes Avenue - Pittsburgh, PA 15213-3890 - (412) 268-4387, fax: (412) 268-7395 - tech-transfer@andrew.cmu.edu - -4. Redistributions of any form whatsoever must retain the following - acknowledgment: - "This product includes software developed by Computing Services - at Carnegie Mellon University (http://www.cmu.edu/computing/)." - -CARNEGIE MELLON UNIVERSITY DISCLAIMS ALL WARRANTIES WITH REGARD TO -THIS SOFTWARE, INCLUDING ALL IMPLIED WARRANTIES OF MERCHANTABILITY -AND FITNESS, IN NO EVENT SHALL CARNEGIE MELLON UNIVERSITY BE LIABLE -FOR ANY SPECIAL, INDIRECT OR CONSEQUENTIAL DAMAGES OR ANY DAMAGES -WHATSOEVER RESULTING FROM LOSS OF USE, DATA OR PROFITS, WHETHER IN -AN ACTION OF CONTRACT, NEGLIGENCE OR OTHER TORTIOUS ACTION, ARISING -OUT OF OR IN CONNECTION WITH THE USE OR PERFORMANCE OF THIS SOFTWARE. diff --git a/options/license/Brian-Gladman-3-Clause b/options/license/Brian-Gladman-3-Clause deleted file mode 100644 index 984c95e3e86a9..0000000000000 --- a/options/license/Brian-Gladman-3-Clause +++ /dev/null @@ -1,26 +0,0 @@ -Copyright (c) 2003, Dr Brian Gladman, Worcester, UK. All rights reserved. - -LICENSE TERMS - -The free distribution and use of this software in both source and binary -form is allowed (with or without changes) provided that: - - 1. distributions of this source code include the above copyright - notice, this list of conditions and the following disclaimer; - - 2. distributions in binary form include the above copyright - notice, this list of conditions and the following disclaimer - in the documentation and/or other associated materials; - - 3. the copyright holder's name is not used to endorse products - built using this software without specific written permission. - -ALTERNATIVELY, provided that this notice is retained in full, this product -may be distributed under the terms of the GNU General Public License (GPL), -in which case the provisions of the GPL apply INSTEAD OF those given above. - -DISCLAIMER - -This software is provided 'as is' with no explicit or implied warranties -in respect of its properties, including, but not limited to, correctness -and/or fitness for purpose. diff --git a/options/license/CC-BY-NC-SA-2.0-DE b/options/license/CC-BY-NC-SA-2.0-DE deleted file mode 100644 index ba4b72ac30ba1..0000000000000 --- a/options/license/CC-BY-NC-SA-2.0-DE +++ /dev/null @@ -1,85 +0,0 @@ -Creative Commons Namensnennung — Nicht-kommerziell — Weitergabe unter gleichen Bedingungen 2.0 - -CREATIVE COMMONS IST KEINE RECHTSANWALTSGESELLSCHAFT UND LEISTET KEINE RECHTSBERATUNG. DIE WEITERGABE DIESES LIZENZENTWURFES FÜHRT ZU KEINEM MANDATSVERHÄLTNIS. CREATIVE COMMONS ERBRINGT DIESE INFORMATIONEN OHNE GEWÄHR. CREATIVE COMMONS ÜBERNIMMT KEINE GEWÄHRLEISTUNG FÜR DIE GELIEFERTEN INFORMATIONEN UND SCHLIEßT DIE HAFTUNG FÜR SCHÄDEN AUS, DIE SICH AUS IHREM GEBRAUCH ERGEBEN. - -Lizenzvertrag - -DAS URHEBERRECHTLICH GESCHÜTZTE WERK ODER DER SONSTIGE SCHUTZGEGENSTAND (WIE UNTEN BESCHRIEBEN) WIRD UNTER DEN BEDINGUNGEN DIESER CREATIVE COMMONS PUBLIC LICENSE („CCPL“ ODER „LIZENZVERTRAG“) ZUR VERFÜGUNG GESTELLT. DER SCHUTZGEGENSTAND IST DURCH DAS URHEBERRECHT UND/ODER EINSCHLÄGIGE GESETZE GESCHÜTZT. - -DURCH DIE AUSÜBUNG EINES DURCH DIESEN LIZENZVERTRAG GEWÄHRTEN RECHTS AN DEM SCHUTZGEGENSTAND ERKLÄREN SIE SICH MIT DEN LIZENZBEDINGUNGEN RECHTSVERBINDLICH EINVERSTANDEN. DER LIZENZGEBER RÄUMT IHNEN DIE HIER BESCHRIEBENEN RECHTE UNTER DER VORAUSSETZUNGEIN, DASS SIE SICH MIT DIESEN VERTRAGSBEDINGUNGEN EINVERSTANDEN ERKLÄREN. - -1. Definitionen - - a. Unter einer „Bearbeitung“ wird eine Übersetzung oder andere Bearbeitung des Werkes verstanden, die Ihre persönliche geistige Schöpfung ist. Eine freie Benutzung des Werkes wird nicht als Bearbeitung angesehen. - - b. Unter den „Lizenzelementen“ werden die folgenden Lizenzcharakteristika verstanden, die vom Lizenzgeber ausgewählt und in der Bezeichnung der Lizenz genannt werden: „Namensnennung“, „Nicht-kommerziell“, „Weitergabe unter gleichen Bedingungen“. - - c. Unter dem „Lizenzgeber“ wird die natürliche oder juristische Person verstanden, die den Schutzgegenstand unter den Bedingungen dieser Lizenz anbietet. - - d. Unter einem „Sammelwerk“ wird eine Sammlung von Werken, Daten oder anderen unabhängigen Elementen verstanden, die aufgrund der Auswahl oder Anordnung der Elemente eine persönliche geistige Schöpfung ist. Darunter fallen auch solche Sammelwerke, deren Elemente systematisch oder methodisch angeordnet und einzeln mit Hilfe elektronischer Mittel oder auf andere Weise zugänglich sind (Datenbankwerke). Ein Sammelwerk wird im Zusammenhang mit dieser Lizenz nicht als Bearbeitung (wie oben beschrieben) angesehen. - - e. Mit „SIE“ und „Ihnen“ ist die natürliche oder juristische Person gemeint, die die durch diese Lizenz gewährten Nutzungsrechte ausübt und die zuvor die Bedingungen dieser Lizenz im Hinblick auf das Werk nicht verletzt hat, oder die die ausdrückliche Erlaubnis des Lizenzgebers erhalten hat, die durch diese Lizenz gewährten Nutzungsrechte trotz einer vorherigen Verletzung auszuüben. - - f. Unter dem „Schutzgegenstand“wird das Werk oder Sammelwerk oder das Schutzobjekt eines verwandten Schutzrechts, das Ihnen unter den Bedingungen dieser Lizenz angeboten wird, verstanden - - g. Unter dem „Urheber“ wird die natürliche Person verstanden, die das Werk geschaffen hat. - - h. Unter einem „verwandten Schutzrecht“ wird das Recht an einem anderen urheberrechtlichen Schutzgegenstand als einem Werk verstanden, zum Beispiel einer wissenschaftlichen Ausgabe, einem nachgelassenen Werk, einem Lichtbild, einer Datenbank, einem Tonträger, einer Funksendung, einem Laufbild oder einer Darbietung eines ausübenden Künstlers. - - i. Unter dem „Werk“ wird eine persönliche geistige Schöpfung verstanden, die Ihnen unter den Bedingungen dieser Lizenz angeboten wird. - -2. Schranken des Urheberrechts. Diese Lizenz lässt sämtliche Befugnisse unberührt, die sich aus den Schranken des Urheberrechts,aus dem Erschöpfungsgrundsatz oder anderen Beschränkungen der Ausschließlichkeitsrechte des Rechtsinhabers ergeben. - -3. Lizenzierung. Unter den Bedingungen dieses Lizenzvertrages räumt Ihnen der Lizenzgeber ein lizenzgebührenfreies, räumlich und zeitlich (für die Dauer des Urheberrechts oder verwandten Schutzrechts) unbeschränktes einfaches Nutzungsrecht ein, den Schutzgegenstand in der folgenden Art und Weise zu nutzen: - - a. den Schutzgegenstand in körperlicher Form zu verwerten, insbesondere zu vervielfältigen, zu verbreiten und auszustellen; - - b. den Schutzgegenstand in unkörperlicher Form öffentlich wiederzugeben, insbesondere vorzutragen, aufzuführen und vorzuführen, öffentlich zugänglich zu machen, zu senden, durch Bild- und Tonträger wiederzugeben sowie Funksendungen und öffentliche Zugänglichmachungen wiederzugeben; - - c. den Schutzgegenstand auf Bild- oder Tonträger aufzunehmen, Lichtbilder davon herzustellen, weiterzusenden und in dem in a. und b. genannten Umfang zu verwerten; - - d. den Schutzgegenstand zu bearbeiten oder in anderer Weise umzugestalten und die Bearbeitungen zu veröffentlichen und in dem in a. bis c. genannten Umfang zu verwerten; - -Die genannten Nutzungsrechte können für alle bekannten Nutzungsarten ausgeübt werden. Die genannten Nutzungsrechte beinhalten das Recht, solche Veränderungen an dem Werk vorzunehmen, die technisch erforderlich sind, um die Nutzungsrechte für alle Nutzungsarten wahrzunehmen. Insbesondere sind davon die Anpassung an andere Medien und auf andere Dateiformate umfasst. - -4. Beschränkungen. Die Einräumung der Nutzungsrechte gemäß Ziffer 3 erfolgt ausdrücklich nur unter den folgenden Bedingungen: - - a. Sie dürfen den Schutzgegenstand ausschließlich unter den Bedingungen dieser Lizenz vervielfältigen, verbreiten oder öffentlich wiedergeben, und Sie müssen stets eine Kopie oder die vollständige Internetadresse in Form des Uniform-Resource-Identifier (URI) dieser Lizenz beifügen, wenn Sie den Schutzgegenstandvervielfältigen, verbreiten oder öffentlich wiedergeben. Sie dürfen keine Vertragsbedingungen anbieten oder fordern, die die Bedingungen dieser Lizenz oder die durch sie gewährten Rechte ändern oder beschränken. Sie dürfen den Schutzgegenstand nicht unterlizenzieren. Sie müssen alle Hinweise unverändert lassen, die auf diese Lizenz und den Haftungsausschluss hinweisen. Sie dürfen den Schutzgegenstand mit keinen technischen Schutzmaßnahmen versehen, die den Zugang oder den Gebrauch des Schutzgegenstandes in einer Weise kontrollieren, die mit den Bedingungen dieser Lizenz im Widerspruch stehen. Die genannten Beschränkungen gelten auch für den Fall, dass der Schutzgegenstand einen Bestandteil eines Sammelwerkes bildet; sie verlangen aber nicht, dass das Sammelwerk insgesamt zum Gegenstand dieser Lizenz gemacht wird. Wenn Sie ein Sammelwerk erstellen, müssen Sie - soweit dies praktikabel ist - auf die Mitteilung eines Lizenzgebers oder Urhebers hin aus dem Sammelwerk jeglichen Hinweis auf diesen Lizenzgeber oder diesen Urheber entfernen. Wenn Sie den Schutzgegenstand bearbeiten, müssen Sie - soweit dies praktikabel ist- auf die Aufforderung eines Rechtsinhabers hin von der Bearbeitung jeglichen Hinweis auf diesen Rechtsinhaber entfernen. - - b. Sie dürfen eine Bearbeitung ausschließlich unter den Bedingungen dieser Lizenz, einer späteren Version dieser Lizenz mit denselben Lizenzelementen wie diese Lizenz oder einer Creative Commons iCommons Lizenz, die dieselben Lizenzelemente wie diese Lizenz enthält (z.B. Namensnennung - Nicht-kommerziell - Weitergabe unter gleichen Bedingungen 2.0 Japan), vervielfältigen, verbreiten oder öffentlich wiedergeben. Sie müssen stets eine Kopie oder die Internetadresse in Form des Uniform-Resource-Identifier (URI) dieser Lizenz oder einer anderen Lizenz der im vorhergehenden Satz beschriebenen Art beifügen, wenn Sie die Bearbeitung vervielfältigen, verbreiten oder öffentlich wiedergeben. Sie dürfen keine Vertragsbedingungen anbieten oder fordern, die die Bedingungen dieser Lizenz oder die durch sie gewährten Rechte ändern oder beschränken, und Sie müssen alle Hinweise unverändert lassen, die auf diese Lizenz und den Haftungsausschluss hinweisen. Sie dürfen eine Bearbeitung nicht mit technischen Schutzmaßnahmen versehen, die den Zugang oder den Gebrauch der Bearbeitung in einer Weise kontrollieren, die mit den Bedingungen dieser Lizenz im Widerspruch stehen. Die genannten Beschränkungen gelten auch für eine Bearbeitung als Bestandteil eines Sammelwerkes; sie erfordern aber nicht, dass das Sammelwerk insgesamt zum Gegenstand dieser Lizenz gemacht wird. - - c. Sie dürfen die in Ziffer 3 gewährten Nutzungsrechte in keiner Weise verwenden, die hauptsächlich auf einen geschäftlichen Vorteil oder eine vertraglich geschuldete geldwerte Vergütung abzielt oder darauf gerichtet ist. Erhalten Sie im Zusammenhang mit der Einräumung der Nutzungsrechte ebenfalls einen Schutzgegenstand, ohne dass eine vertragliche Verpflichtung hierzu besteht, so wird dies nicht als geschäftlicher Vorteil oder vertraglich geschuldete geldwerte Vergütung angesehen, wenn keine Zahlung oder geldwerte Vergütung in Verbindung mit dem Austausch der Schutzgegenstände geleistet wird (z.B. File-Sharing). - - d. Wenn Sie den Schutzgegenstand oder eine Bearbeitung oder ein Sammelwerk vervielfältigen, verbreiten oder öffentlich wiedergeben, müssen Sie alle Urhebervermerke für den Schutzgegenstand unverändert lassen und die Urheberschaft oder Rechtsinhaberschaft in einer der von Ihnen vorgenommenen Nutzung angemessenen Form anerkennen, indem Sie den Namen (oder das Pseudonym, falls ein solches verwendet wird) des Urhebers oder Rechteinhabers nennen, wenn dieser angegeben ist. Dies gilt auch für den Titel des Schutzgegenstandes, wenn dieser angeben ist, sowie - in einem vernünftigerweise durchführbaren Umfang - für die mit dem Schutzgegenstand zu verbindende Internetadresse in Form des Uniform-Resource-Identifier (URI), wie sie der Lizenzgeber angegeben hat, sofern dies geschehen ist, es sei denn, diese Internetadresse verweist nicht auf den Urhebervermerk oder die Lizenzinformationen zu dem Schutzgegenstand. Bei einer Bearbeitung ist ein Hinweis darauf aufzuführen, in welcher Form der Schutzgegenstand in die Bearbeitung eingegangen ist (z.B. „Französische Übersetzung des ... (Werk) durch ... (Urheber)“ oder „Das Drehbuch beruht auf dem Werk des ... (Urheber)“). Ein solcher Hinweis kann in jeder angemessenen Weise erfolgen, wobei jedoch bei einer Bearbeitung, einer Datenbank oder einem Sammelwerk der Hinweis zumindest an gleicher Stelle und in ebenso auffälliger Weise zu erfolgen hat wie vergleichbare Hinweise auf andere Rechtsinhaber. - - e. Obwohl die gemäss Ziffer 3 gewährten Nutzungsrechte in umfassender Weise ausgeübt werden dürfen, findet diese Erlaubnis ihre gesetzliche Grenze in den Persönlichkeitsrechten der Urheber und ausübenden Künstler, deren berechtigte geistige und persönliche Interessen bzw. deren Ansehen oder Ruf nicht dadurch gefährdet werden dürfen, dass ein Schutzgegenstand über das gesetzlich zulässige Maß hinaus beeinträchtigt wird. - -5. Gewährleistung. Sofern dies von den Vertragsparteien nicht anderweitig schriftlich vereinbart,, bietet der Lizenzgeber keine Gewährleistung für die erteilten Rechte, außer für den Fall, dass Mängel arglistig verschwiegen wurden. Für Mängel anderer Art, insbesondere bei der mangelhaften Lieferung von Verkörperungen des Schutzgegenstandes, richtet sich die Gewährleistung nach der Regelung, die die Person, die Ihnen den Schutzgegenstand zur Verfügung stellt, mit Ihnen außerhalb dieser Lizenz vereinbart, oder - wenn eine solche Regelung nicht getroffen wurde - nach den gesetzlichen Vorschriften. - -6. Haftung. Über die in Ziffer 5 genannte Gewährleistung hinaus haftet Ihnen der Lizenzgeber nur für Vorsatz und grobe Fahrlässigkeit. - -7. Vertragsende - - a. Dieser Lizenzvertrag und die durch ihn eingeräumten Nutzungsrechte enden automatisch bei jeder Verletzung der Vertragsbedingungen durch Sie. Für natürliche und juristische Personen, die von Ihnen eine Bearbeitung, eine Datenbank oder ein Sammelwerk unter diesen Lizenzbedingungen erhalten haben, gilt die Lizenz jedoch weiter, vorausgesetzt, diese natürlichen oder juristischen Personen erfüllen sämtliche Vertragsbedingungen. Die Ziffern 1, 2, 5, 6, 7 und 8 gelten bei einer Vertragsbeendigung fort. - - b. Unter den oben genannten Bedingungen erfolgt die Lizenz auf unbegrenzte Zeit (für die Dauer des Schutzrechts). Dennoch behält sich der Lizenzgeber das Recht vor, den Schutzgegenstand unter anderen Lizenzbedingungen zu nutzen oder die eigene Weitergabe des Schutzgegenstandes jederzeit zu beenden, vorausgesetzt, dass solche Handlungen nicht dem Widerruf dieser Lizenz dienen (oder jeder anderen Lizenzierung, die auf Grundlage dieser Lizenz erfolgt ist oder erfolgen muss) und diese Lizenz wirksam bleibt, bis Sie unter den oben genannten Voraussetzungen endet. - -8. Schlussbestimmungen - - a. Jedes Mal, wenn Sie den Schutzgegenstand vervielfältigen, verbreiten oder öffentlich wiedergeben, bietet der Lizenzgeber dem Erwerber eine Lizenz für den Schutzgegenstand unter denselben Vertragsbedingungen an, unter denen er Ihnen die Lizenz eingeräumt hat. - - b. Jedes Mal, wenn Sie eine Bearbeitung vervielfältigen, verbreiten oder öffentlich wiedergeben, bietet der Lizenzgeber dem Erwerber eine Lizenz für den ursprünglichen Schutzgegenstand unter denselben Vertragsbedingungen an, unter denen er Ihnen die Lizenz eingeräumt hat. - - c. Sollte eine Bestimmung dieses Lizenzvertrages unwirksam sein, so wird die Wirksamkeit der übrigen Lizenzbestimmungen dadurch nicht berührt, und an die Stelle der unwirksamen Bestimmung tritt eine Ersatzregelung, die dem mit der unwirksamen Bestimmung angestrebten Zweck am nächsten kommt. - - d. Nichts soll dahingehend ausgelegt werden, dass auf eine Bestimmung dieses Lizenzvertrages verzichtet oder einer Vertragsverletzung zugestimmt wird, so lange ein solcher Verzicht oder eine solche Zustimmung nicht schriftlich vorliegen und von der verzichtenden oder zustimmenden Vertragspartei unterschrieben sind - - e. Dieser Lizenzvertrag stellt die vollständige Vereinbarung zwischen den Vertragsparteien hinsichtlich des Schutzgegenstandes dar. Es gibt keine weiteren ergänzenden Vereinbarungen oder mündlichen Abreden im Hinblick auf den Schutzgegenstand. Der Lizenzgeber ist an keine zusätzlichen Abreden gebunden, die aus irgendeiner Absprache mit Ihnen entstehen könnten. Der Lizenzvertrag kann nicht ohne eine übereinstimmende schriftliche Vereinbarung zwischen dem Lizenzgeber und Ihnen abgeändert werden. - - f. Auf diesen Lizenzvertrag findet das Recht der Bundesrepublik Deutschland Anwendung. - -CREATIVE COMMONS IST KEINE VERTRAGSPARTEI DIESES LIZENZVERTRAGES UND ÜBERNIMMT KEINERLEI GEWÄHRLEISTUNG FÜR DAS WERK. CREATIVE COMMONS IST IHNEN ODER DRITTEN GEGENÜBER NICHT HAFTBAR FÜR SCHÄDEN JEDWEDER ART. UNGEACHTET DER VORSTEHENDEN ZWEI (2) SÄTZE HAT CREATIVE COMMONS ALL RECHTE UND PFLICHTEN EINES LIZENSGEBERS, WENN SICH CREATIVE COMMONS AUSDRÜCKLICH ALS LIZENZGEBER BEZEICHNET. - -AUSSER FÜR DEN BESCHRÄNKTEN ZWECK EINES HINWEISES AN DIE ÖFFENTLICHKEIT, DASS DAS WERK UNTER DER CCPL LIZENSIERT WIRD, DARF KENIE VERTRAGSPARTEI DIE MARKE “CREATIVE COMMONS” ODER EINE ÄHNLICHE MARKE ODER DAS LOGO VON CREATIVE COMMONS OHNE VORHERIGE GENEHMIGUNG VON CREATIVE COMMONS NUTZEN. JEDE GESTATTETE NUTZUNG HAT IN ÜBREEINSTIMMUNG MIT DEN JEWEILS GÜLTIGEN NUTZUNGSBEDINGUNGEN FÜR MARKEN VON CREATIVE COMMONS ZU ERFOLGEN, WIE SIE AUF DER WEBSITE ODER IN ANDERER WEISE AUF ANFRAGE VON ZEIT ZU ZEIT ZUGÄNGLICH GEMACHT WERDEN. - -CREATIVE COMMONS KANN UNTER https://creativecommons.org KONTAKTIERT WERDEN. diff --git a/options/license/CFITSIO b/options/license/CFITSIO deleted file mode 100644 index f2c502057266a..0000000000000 --- a/options/license/CFITSIO +++ /dev/null @@ -1,7 +0,0 @@ -Copyright (Unpublished-all rights reserved under the copyright laws of the United States), U.S. Government as represented by the Administrator of the National Aeronautics and Space Administration. No copyright is claimed in the United States under Title 17, U.S. Code. - -Permission to freely use, copy, modify, and distribute this software and its documentation without fee is hereby granted, provided that this copyright notice and disclaimer of warranty appears in all copies. - -DISCLAIMER: - -THE SOFTWARE IS PROVIDED 'AS IS' WITHOUT ANY WARRANTY OF ANY KIND, EITHER EXPRESSED, IMPLIED, OR STATUTORY, INCLUDING, BUT NOT LIMITED TO, ANY WARRANTY THAT THE SOFTWARE WILL CONFORM TO SPECIFICATIONS, ANY IMPLIED WARRANTIES OF MERCHANTABILITY, FITNESS FOR A PARTICULAR PURPOSE, AND FREEDOM FROM INFRINGEMENT, AND ANY WARRANTY THAT THE DOCUMENTATION WILL CONFORM TO THE SOFTWARE, OR ANY WARRANTY THAT THE SOFTWARE WILL BE ERROR FREE. IN NO EVENT SHALL NASA BE LIABLE FOR ANY DAMAGES, INCLUDING, BUT NOT LIMITED TO, DIRECT, INDIRECT, SPECIAL OR CONSEQUENTIAL DAMAGES, ARISING OUT OF, RESULTING FROM, OR IN ANY WAY CONNECTED WITH THIS SOFTWARE, WHETHER OR NOT BASED UPON WARRANTY, CONTRACT, TORT , OR OTHERWISE, WHETHER OR NOT INJURY WAS SUSTAINED BY PERSONS OR PROPERTY OR OTHERWISE, AND WHETHER OR NOT LOSS WAS SUSTAINED FROM, OR AROSE OUT OF THE RESULTS OF, OR USE OF, THE SOFTWARE OR SERVICES PROVIDED HEREUNDER." diff --git a/options/license/CMU-Mach b/options/license/CMU-Mach deleted file mode 100644 index 1bb895d4eca77..0000000000000 --- a/options/license/CMU-Mach +++ /dev/null @@ -1,22 +0,0 @@ -Copyright (c) 1991,1990,1989 Carnegie Mellon University -All Rights Reserved. - -Permission to use, copy, modify and distribute this software and its -documentation is hereby granted, provided that both the copyright -notice and this permission notice appear in all copies of the -software, derivative works or modified versions, and any portions -thereof, and that both notices appear in supporting documentation. - -CARNEGIE MELLON ALLOWS FREE USE OF THIS SOFTWARE IN ITS "AS IS" -CONDITION. CARNEGIE MELLON DISCLAIMS ANY LIABILITY OF ANY KIND FOR -ANY DAMAGES WHATSOEVER RESULTING FROM THE USE OF THIS SOFTWARE. - -Carnegie Mellon requests users of this software to return to - - Software Distribution Coordinator or Software.Distribution@CS.CMU.EDU - School of Computer Science - Carnegie Mellon University - Pittsburgh PA 15213-3890 - -any improvements or extensions that they make and grant Carnegie Mellon -the rights to redistribute these changes. diff --git a/options/license/Clips b/options/license/Clips deleted file mode 100644 index ff5afdd293138..0000000000000 --- a/options/license/Clips +++ /dev/null @@ -1,15 +0,0 @@ -Permission is hereby granted, free of charge, to any person obtaining -a copy of this software and associated documentation files (the -"Software"), to deal in the Software without restriction, including -without limitation the rights to use, copy, modify, merge, publish, -distribute, and/or sell copies of the Software, and to permit persons -to whom the Software is furnished to do so. - -THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS -OR IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF -MERCHANTABILITY, FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT -OF THIRD PARTY RIGHTS. IN NO EVENT SHALL THE AUTHORS BE LIABLE FOR ANY -CLAIM, OR ANY SPECIAL INDIRECT OR CONSEQUENTIAL DAMAGES, OR ANY DAMAGES -WHATSOEVER RESULTING FROM LOSS OF USE, DATA OR PROFITS, WHETHER IN AN -ACTION OF CONTRACT, NEGLIGENCE OR OTHER TORTIOUS ACTION, ARISING OUT OF -OR IN CONNECTION WITH THE USE OR PERFORMANCE OF THIS SOFTWARE. diff --git a/options/license/Cornell-Lossless-JPEG b/options/license/Cornell-Lossless-JPEG deleted file mode 100644 index 7d2d44394d273..0000000000000 --- a/options/license/Cornell-Lossless-JPEG +++ /dev/null @@ -1,20 +0,0 @@ -Copyright (c) 1993 Cornell University, Kongji Huang -All rights reserved. - -Permission to use, copy, modify, and distribute this software and its -documentation for any purpose, without fee, and without written -agreement is hereby granted, provided that the above copyright notice -and the following two paragraphs appear in all copies of this -software. - -IN NO EVENT SHALL THE CORNELL UNIVERSITY BE LIABLE TO ANY PARTY FOR -DIRECT, INDIRECT, SPECIAL, INCIDENTAL, OR CONSEQUENTIAL DAMAGES ARISING -OUT OF THE USE OF THIS SOFTWARE AND ITS DOCUMENTATION, EVEN IF CORNELL -UNIVERSITY HAS BEEN ADVISED OF THE POSSIBILITY OF SUCH DAMAGE. - -THE CORNELL UNIVERSITY SPECIFICALLY DISCLAIMS ANY WARRANTIES, -INCLUDING, BUT NOT LIMITED TO, THE IMPLIED WARRANTIES OF -MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE. THE SOFTWARE -PROVIDED HEREUNDER IS ON AN "AS IS" BASIS, AND CORNELL UNIVERSITY HAS -NO OBLIGATION TO PROVIDE MAINTENANCE, SUPPORT, UPDATES, ENHANCEMENTS, -OR MODIFICATIONS. diff --git a/options/license/GNAT-exception b/options/license/GNAT-exception deleted file mode 100644 index 2b5a96a62b08a..0000000000000 --- a/options/license/GNAT-exception +++ /dev/null @@ -1,6 +0,0 @@ -As a special exception, if other files instantiate generics from this -unit, or you link this unit with other files to produce an executable, -this unit does not by itself cause the resulting executable to be -covered by the GNU General Public License. This exception does not -however invalidate any other reasons why the executable file might be -covered by the GNU Public License. diff --git a/options/license/HP-1986 b/options/license/HP-1986 deleted file mode 100644 index 35844cb4d852a..0000000000000 --- a/options/license/HP-1986 +++ /dev/null @@ -1,10 +0,0 @@ -(c) Copyright 1986 HEWLETT-PACKARD COMPANY - -To anyone who acknowledges that this file is provided "AS IS" -without any express or implied warranty: permission to use, copy, -modify, and distribute this file for any purpose is hereby granted -without fee, provided that the above copyright notice and this notice -appears in all copies, and that the name of Hewlett-Packard Company -not be used in advertising or publicity pertaining to distribution -of the software without specific, written prior permission. Hewlett-Packard -Company makes no representations about the suitability of this software for any purpose. diff --git a/options/license/HPND-Markus-Kuhn b/options/license/HPND-Markus-Kuhn deleted file mode 100644 index ca41db16188de..0000000000000 --- a/options/license/HPND-Markus-Kuhn +++ /dev/null @@ -1,3 +0,0 @@ -Permission to use, copy, modify, and distribute this software -for any purpose and without fee is hereby granted. The author -disclaims all warranties with regard to this software. diff --git a/options/license/HPND-sell-variant-MIT-disclaimer b/options/license/HPND-sell-variant-MIT-disclaimer deleted file mode 100644 index d4464e0c35cb9..0000000000000 --- a/options/license/HPND-sell-variant-MIT-disclaimer +++ /dev/null @@ -1,20 +0,0 @@ -by Jim Knoble - Copyright (C) 1999,2000,2001 Jim Knoble - - Permission to use, copy, modify, distribute, and sell this software - and its documentation for any purpose is hereby granted without fee, - provided that the above copyright notice appear in all copies and - that both that copyright notice and this permission notice appear in - supporting documentation. - -+------------+ -| Disclaimer | -+------------+ - - THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, - express or implied, including but not limited to the warranties of - merchantability, fitness for a particular purpose and - noninfringement. In no event shall the author(s) be liable for any - claim, damages or other liability, whether in an action of contract, - tort or otherwise, arising from, out of or in connection with the - software or the use or other dealings in the software. diff --git a/options/license/IEC-Code-Components-EULA b/options/license/IEC-Code-Components-EULA deleted file mode 100644 index b74269afd9b91..0000000000000 --- a/options/license/IEC-Code-Components-EULA +++ /dev/null @@ -1,37 +0,0 @@ -IEC Code Components End-user licence agreement - -Code Components in IEC standards (International Standards, Technical Specifications or -Technical Reports) which have been identified and approved for licensing, are licensed subject to -the following conditions: - -- Redistributions of software must retain the Copyright Notice, this list of conditions and the -disclaimer below (“Disclaimer”). -- The software license extends to modifications permitted under the relevant IEC standard. -- The software license extends to clarifications and corrections approved by IEC. -- Neither the name of IEC, nor the names of specific contributors, may be used to endorse or -promote products derived from this software without specific prior written permission. The -relevant IEC standard may be referenced when claiming compliance with the relevant IEC -standard. -- The user of Code Components shall attribute each such Code Component to IEC and identify -the IEC standard from which it is taken. Such attribution (e.g., “This code was derived from IEC -[insert standard reference number:publication year] within modifications permitted in the -relevant IEC standard. Please reproduce this note if possible.”), may be placed in the code itself -or any other reasonable location. - -Code Components means components included in IEC standards that are intended to be directly -processed by a computer and also includes any text found between the markers and , or otherwise clearly labeled in this standard as a Code -Component. - -The Disclaimer is: -EACH OF THE CODE COMPONENTS IS PROVIDED BY THE COPYRIGHT HOLDERS AND -CONTRIBUTORS “AS IS” AND ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT -NOT LIMITED TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A -PARTICULAR PURPOSE ARE DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT OWNER -OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, -EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT LIMITED TO, -PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR -PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF -LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING -NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE OF THE CODE -COMPONENTS, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE. diff --git a/options/license/JPL-image b/options/license/JPL-image deleted file mode 100644 index 828b1b5424ec4..0000000000000 --- a/options/license/JPL-image +++ /dev/null @@ -1,21 +0,0 @@ -JPL Image Use Policy - -Unless otherwise noted, images and video on JPL public web sites (public sites ending with a jpl.nasa.gov address) may be used for any purpose without prior permission, subject to the special cases noted below. Publishers who wish to have authorization may print this page and retain it for their records; JPL does not issue image permissions on an image by image basis. - -By electing to download the material from this web site the user agrees: - -1. that Caltech makes no representations or warranties with respect to ownership of copyrights in the images, and does not represent others who may claim to be authors or owners of copyright of any of the images, and makes no warranties as to the quality of the images. Caltech shall not be responsible for any loss or expenses resulting from the use of the images, and you release and hold Caltech harmless from all liability arising from such use. -2. to use a credit line in connection with images. Unless otherwise noted in the caption information for an image, the credit line should be "Courtesy NASA/JPL-Caltech." -3. that the endorsement of any product or service by Caltech, JPL or NASA must not be claimed or implied. - -Special Cases: - -* Prior written approval must be obtained to use the NASA insignia logo (the blue "meatball" insignia), the NASA logotype (the red "worm" logo) and the NASA seal. These images may not be used by persons who are not NASA employees or on products (including Web pages) that are not NASA sponsored. In addition, no image may be used to explicitly or implicitly suggest endorsement by NASA, JPL or Caltech of commercial goods or services. Requests to use NASA logos may be directed to Bert Ulrich, Public Services Division, NASA Headquarters, Code POS, Washington, DC 20546, telephone (202) 358-1713, fax (202) 358-4331, email bert.ulrich@hq.nasa.gov. - -* Prior written approval must be obtained to use the JPL logo (stylized JPL letters in red or other colors). Requests to use the JPL logo may be directed to the Institutional Communications Office, email instcomm@jpl.nasa.gov. - -* If an image includes an identifiable person, using the image for commercial purposes may infringe that person's right of privacy or publicity, and permission should be obtained from the person. NASA and JPL generally do not permit likenesses of current employees to appear on commercial products. For more information, consult the NASA and JPL points of contact listed above. - -* JPL/Caltech contractors and vendors who wish to use JPL images in advertising or public relation materials should direct requests to the Institutional Communications Office, email instcomm@jpl.nasa.gov. - -* Some image and video materials on JPL public web sites are owned by organizations other than JPL or NASA. These owners have agreed to make their images and video available for journalistic, educational and personal uses, but restrictions are placed on commercial uses. To obtain permission for commercial use, contact the copyright owner listed in each image caption. Ownership of images and video by parties other than JPL and NASA is noted in the caption material with each image. diff --git a/options/license/Kazlib b/options/license/Kazlib deleted file mode 100644 index 714f2eabf9cc5..0000000000000 --- a/options/license/Kazlib +++ /dev/null @@ -1,4 +0,0 @@ -Copyright (C) 1999 Kaz Kylheku - -Free Software License: -All rights are reserved by the author, with the following exceptions: Permission is granted to freely reproduce and distribute this software, possibly in exchange for a fee, provided that this copyright notice appears intact. Permission is also granted to adapt this software to produce derivative works, as long as the modified versions carry this copyright notice and additional notices stating that the work has been modified. This source code may be translated into executable form and incorporated into proprietary software; there is no requirement for such software to contain a copyright notice related to this source. diff --git a/options/license/Martin-Birgmeier b/options/license/Martin-Birgmeier deleted file mode 100644 index 48d32f846e5b7..0000000000000 --- a/options/license/Martin-Birgmeier +++ /dev/null @@ -1,5 +0,0 @@ -Copyright (c) 1993 Martin Birgmeier All rights reserved. - -You may redistribute unmodified or modified versions of this source code provided that the above copyright notice and this and the following conditions are retained. - -This software is provided ``as is'', and comes with no warranties of any kind. I shall in no event be liable for anything that happens to anyone/anything when using this software. diff --git a/options/license/OFFIS b/options/license/OFFIS deleted file mode 100644 index ad48f181c39bc..0000000000000 --- a/options/license/OFFIS +++ /dev/null @@ -1,22 +0,0 @@ -Copyright (C) 1994-2001, OFFIS - -This software and supporting documentation were developed by - -Kuratorium OFFIS e.V. -Healthcare Information and Communication Systems -Escherweg 2 -D-26121 Oldenburg, Germany - -THIS SOFTWARE IS MADE AVAILABLE, AS IS, AND OFFIS MAKES NO WARRANTY -REGARDING THE SOFTWARE, ITS PERFORMANCE, ITS MERCHANTABILITY OR -FITNESS FOR ANY PARTICULAR USE, FREEDOM FROM ANY COMPUTER DISEASES OR -ITS CONFORMITY TO ANY SPECIFICATION. THE ENTIRE RISK AS TO QUALITY AND -PERFORMANCE OF THE SOFTWARE IS WITH THE USER. - -Copyright of the software and supporting documentation is, unless -otherwise stated, owned by OFFIS, and free access is hereby granted as -a license to use this software, copy this software and prepare -derivative works based upon this software. However, any distribution -of this software source code or supporting documentation or derivative -works (source code and supporting documentation) must include the -three paragraphs of this copyright notice. diff --git a/options/license/OpenPBS-2.3 b/options/license/OpenPBS-2.3 deleted file mode 100644 index 61f52c22021cc..0000000000000 --- a/options/license/OpenPBS-2.3 +++ /dev/null @@ -1,76 +0,0 @@ - - OpenPBS (Portable Batch System) v2.3 Software License - -Copyright (c) 1999-2000 Veridian Information Solutions, Inc. -All rights reserved. - ---------------------------------------------------------------------------- -For a license to use or redistribute the OpenPBS software under conditions -other than those described below, or to purchase support for this software, -please contact Veridian Systems, PBS Products Department ("Licensor") at: - - www.OpenPBS.org +1 650 967-4675 sales@OpenPBS.org - 877 902-4PBS (US toll-free) ---------------------------------------------------------------------------- - -This license covers use of the OpenPBS v2.3 software (the "Software") at -your site or location, and, for certain users, redistribution of the -Software to other sites and locations. Use and redistribution of -OpenPBS v2.3 in source and binary forms, with or without modification, -are permitted provided that all of the following conditions are met. -After December 31, 2001, only conditions 3-6 must be met: - -1. Commercial and/or non-commercial use of the Software is permitted - provided a current software registration is on file at www.OpenPBS.org. - If use of this software contributes to a publication, product, or - service, proper attribution must be given; see www.OpenPBS.org/credit.html - -2. Redistribution in any form is only permitted for non-commercial, - non-profit purposes. There can be no charge for the Software or any - software incorporating the Software. Further, there can be no - expectation of revenue generated as a consequence of redistributing - the Software. - -3. Any Redistribution of source code must retain the above copyright notice - and the acknowledgment contained in paragraph 6, this list of conditions - and the disclaimer contained in paragraph 7. - -4. Any Redistribution in binary form must reproduce the above copyright - notice and the acknowledgment contained in paragraph 6, this list of - conditions and the disclaimer contained in paragraph 7 in the - documentation and/or other materials provided with the distribution. - -5. Redistributions in any form must be accompanied by information on how to - obtain complete source code for the OpenPBS software and any - modifications and/or additions to the OpenPBS software. The source code - must either be included in the distribution or be available for no more - than the cost of distribution plus a nominal fee, and all modifications - and additions to the Software must be freely redistributable by any party - (including Licensor) without restriction. - -6. All advertising materials mentioning features or use of the Software must - display the following acknowledgment: - - "This product includes software developed by NASA Ames Research Center, - Lawrence Livermore National Laboratory, and Veridian Information Solutions, - Inc. Visit www.OpenPBS.org for OpenPBS software support, - products, and information." - -7. DISCLAIMER OF WARRANTY - -THIS SOFTWARE IS PROVIDED "AS IS" WITHOUT WARRANTY OF ANY KIND. ANY EXPRESS -OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED WARRANTIES -OF MERCHANTABILITY, FITNESS FOR A PARTICULAR PURPOSE, AND NON-INFRINGEMENT -ARE EXPRESSLY DISCLAIMED. - -IN NO EVENT SHALL VERIDIAN CORPORATION, ITS AFFILIATED COMPANIES, OR THE -U.S. GOVERNMENT OR ANY OF ITS AGENCIES BE LIABLE FOR ANY DIRECT OR INDIRECT, -INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT -LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, -OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF -LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING -NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, -EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE. - -This license will be governed by the laws of the Commonwealth of Virginia, -without reference to its choice of law rules. diff --git a/options/license/QPL-1.0-INRIA-2004 b/options/license/QPL-1.0-INRIA-2004 deleted file mode 100644 index 45d946e2e239a..0000000000000 --- a/options/license/QPL-1.0-INRIA-2004 +++ /dev/null @@ -1,102 +0,0 @@ - THE Q PUBLIC LICENSE version 1.0 - - Copyright (C) 1999 Troll Tech AS, Norway. - Everyone is permitted to copy and - distribute this license document. - -The intent of this license is to establish freedom to share and change -the software regulated by this license under the open source model. - -This license applies to any software containing a notice placed by the -copyright holder saying that it may be distributed under the terms of -the Q Public License version 1.0. Such software is herein referred to -as the Software. This license covers modification and distribution of -the Software, use of third-party application programs based on the -Software, and development of free software which uses the Software. - - Granted Rights - -1. You are granted the non-exclusive rights set forth in this license -provided you agree to and comply with any and all conditions in this -license. Whole or partial distribution of the Software, or software -items that link with the Software, in any form signifies acceptance of -this license. - -2. You may copy and distribute the Software in unmodified form -provided that the entire package, including - but not restricted to - -copyright, trademark notices and disclaimers, as released by the -initial developer of the Software, is distributed. - -3. You may make modifications to the Software and distribute your -modifications, in a form that is separate from the Software, such as -patches. The following restrictions apply to modifications: - - a. Modifications must not alter or remove any copyright notices - in the Software. - - b. When modifications to the Software are released under this - license, a non-exclusive royalty-free right is granted to the - initial developer of the Software to distribute your - modification in future versions of the Software provided such - versions remain available under these terms in addition to any - other license(s) of the initial developer. - -4. You may distribute machine-executable forms of the Software or -machine-executable forms of modified versions of the Software, -provided that you meet these restrictions: - - a. You must include this license document in the distribution. - - b. You must ensure that all recipients of the machine-executable - forms are also able to receive the complete machine-readable - source code to the distributed Software, including all - modifications, without any charge beyond the costs of data - transfer, and place prominent notices in the distribution - explaining this. - - c. You must ensure that all modifications included in the - machine-executable forms are available under the terms of this - license. - -5. You may use the original or modified versions of the Software to -compile, link and run application programs legally developed by you or -by others. - -6. You may develop application programs, reusable components and other -software items that link with the original or modified versions of the -Software. These items, when distributed, are subject to the following -requirements: - - a. You must ensure that all recipients of machine-executable - forms of these items are also able to receive and use the - complete machine-readable source code to the items without any - charge beyond the costs of data transfer. - - b. You must explicitly license all recipients of your items to - use and re-distribute original and modified versions of the - items in both machine-executable and source code forms. The - recipients must be able to do so without any charges whatsoever, - and they must be able to re-distribute to anyone they choose. - - c. If the items are not available to the general public, and the - initial developer of the Software requests a copy of the items, - then you must supply one. - - Limitations of Liability - -In no event shall the initial developers or copyright holders be -liable for any damages whatsoever, including - but not restricted to - -lost revenue or profits or other direct, indirect, special, incidental -or consequential damages, even if they have been advised of the -possibility of such damages, except to the extent invariable law, if -any, provides otherwise. - - No Warranty - -The Software and this license document are provided AS IS with NO -WARRANTY OF ANY KIND, INCLUDING THE WARRANTY OF DESIGN, -MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE. - - Choice of Law - -This license is governed by the Laws of France. diff --git a/options/license/QPL-1.0-INRIA-2004-exception b/options/license/QPL-1.0-INRIA-2004-exception deleted file mode 100644 index 2418a26377cdb..0000000000000 --- a/options/license/QPL-1.0-INRIA-2004-exception +++ /dev/null @@ -1,5 +0,0 @@ -As a special exception to the Q Public Licence, you may develop -application programs, reusable components and other software items -that link with the original or modified versions of the Software -and are not made available to the general public, without any of the -additional requirements listed in clause 6c of the Q Public licence. diff --git a/options/license/SWI-exception b/options/license/SWI-exception deleted file mode 100644 index 9ccfb9b89cf8a..0000000000000 --- a/options/license/SWI-exception +++ /dev/null @@ -1,6 +0,0 @@ -As a special exception, if you link this library with other files, -compiled with a Free Software compiler, to produce an executable, this -library does not by itself cause the resulting executable to be covered -by the GNU General Public License. This exception does not however -invalidate any other reasons why the executable file might be covered by -the GNU General Public License. diff --git a/options/license/SunPro b/options/license/SunPro deleted file mode 100644 index 1ccb78add07bb..0000000000000 --- a/options/license/SunPro +++ /dev/null @@ -1,6 +0,0 @@ -Copyright (C) 1993 by Sun Microsystems, Inc. All rights reserved. - -Developed at SunSoft, a Sun Microsystems, Inc. business. -Permission to use, copy, modify, and distribute this -software is freely granted, provided that this notice -is preserved. diff --git a/options/license/TPL-1.0 b/options/license/TPL-1.0 deleted file mode 100644 index 1634db4912ed4..0000000000000 --- a/options/license/TPL-1.0 +++ /dev/null @@ -1,475 +0,0 @@ -THOR Public Licence (TPL) - -0. Notes of Origin - -0.1 As required by paragraph 6.3 of the "Mozilla Public Licence", -"MPL" in the following, it is hereby stated that this Licence -condition ("TPL") differs in the following items from the original -"Mozilla Public Licence" as provided by "Netscape Communications -Corporation": - -a) Paragraphs 6.2 and 6.3 of the MPL has been modified to bind licence -modifications to the Author of this Licence, Thomas Richter. - -b) Paragraph 11 has been modified to gover this Licence by German -law rather than Californian Law. - -c) The licence has been renamed to "TPL" and "THOR Public -Licence". All references towards "MPL" have been removed except in -section 0 to indicate the difference from "MPL". - -No other modifications have been made. - - -1. Definitions. - -1.0.1. "Commercial Use" means distribution or otherwise making the -Covered Code available to a third party. - -1.1. "Contributor" means each entity that creates or contributes to -the creation of Modifications. - -1.2. "Contributor Version" means the combination of the Original Code, -prior Modifications used by a Contributor, and the Modifications made -by that particular Contributor. - -1.3. "Covered Code" means the Original Code or Modifications or the -combination of the Original Code and Modifications, in each case -including portions thereof. - -1.4. "Electronic Distribution Mechanism" means a mechanism generally -accepted in the software development community for the electronic -transfer of data. - -1.5. "Executable" means Covered Code in any form other than Source -Code. - -1.6. "Initial Developer" means the individual or entity identified as -the Initial Developer in the Source Code notice required by Exhibit A. - -1.7. "Larger Work" means a work which combines Covered Code or -portions thereof with code not governed by the terms of this License. - -1.8. "License" means this document. - -1.8.1. "Licensable" means having the right to grant, to the maximum -extent possible, whether at the time of the initial grant or -subsequently acquired, any and all of the rights conveyed herein. - -1.9. "Modifications" means any addition to or deletion from the -substance or structure of either the Original Code or any previous -Modifications. When Covered Code is released as a series of files, a -Modification is: A. Any addition to or deletion from the contents of a -file containing Original Code or previous Modifications. - -B. Any new file that contains any part of the Original Code or -previous Modifications. - -1.10. "Original Code" means Source Code of computer software code -which is described in the Source Code notice required by Exhibit A as -Original Code, and which, at the time of its release under this -License is not already Covered Code governed by this License. - -1.10.1. "Patent Claims" means any patent claim(s), now owned or -hereafter acquired, including without limitation, method, process, and -apparatus claims, in any patent Licensable by grantor. - -1.11. "Source Code" means the preferred form of the Covered Code for -making modifications to it, including all modules it contains, plus -any associated interface definition files, scripts used to control -compilation and installation of an Executable, or source code -differential comparisons against either the Original Code or another -well known, available Covered Code of the Contributor's choice. The -Source Code can be in a compressed or archival form, provided the -appropriate decompression or de-archiving software is widely available -for no charge. - -1.12. "You" (or "Your") means an individual or a legal entity -exercising rights under, and complying with all of the terms of, this -License or a future version of this License issued under Section -6.1. For legal entities, "You" includes any entity which controls, is -controlled by, or is under common control with You. For purposes of -this definition, "control" means (a) the power, direct or indirect, to -cause the direction or management of such entity, whether by contract -or otherwise, or (b) ownership of more than fifty percent (50%) of the -outstanding shares or beneficial ownership of such entity. - -2. Source Code License. - -2.1. The Initial Developer Grant. The Initial Developer hereby grants -You a world-wide, royalty-free, non-exclusive license, subject to -third party intellectual property claims: (a) under intellectual -property rights (other than patent or trademark) Licensable by Initial -Developer to use, reproduce, modify, display, perform, sublicense and -distribute the Original Code (or portions thereof) with or without -Modifications, and/or as part of a Larger Work; and - -(b) under Patents Claims infringed by the making, using or selling of -Original Code, to make, have made, use, practice, sell, and offer for -sale, and/or otherwise dispose of the Original Code (or portions -thereof). - -(c) the licenses granted in this Section 2.1(a) and (b) are effective -on the date Initial Developer first distributes Original Code under -the terms of this License. - -(d) Notwithstanding Section 2.1(b) above, no patent license is -granted: 1) for code that You delete from the Original Code; 2) -separate from the Original Code; or 3) for infringements caused by: i) -the modification of the Original Code or ii) the combination of the -Original Code with other software or devices. - -2.2. Contributor Grant. Subject to third party intellectual property -claims, each Contributor hereby grants You a world-wide, royalty-free, -non-exclusive license - -(a) under intellectual property rights (other than patent or -trademark) Licensable by Contributor, to use, reproduce, modify, -display, perform, sublicense and distribute the Modifications created -by such Contributor (or portions thereof) either on an unmodified -basis, with other Modifications, as Covered Code and/or as part of a -Larger Work; and - -(b) under Patent Claims infringed by the making, using, or selling of -Modifications made by that Contributor either alone and/or in -combination with its Contributor Version (or portions of such -combination), to make, use, sell, offer for sale, have made, and/or -otherwise dispose of: 1) Modifications made by that Contributor (or -portions thereof); and 2) the combination of Modifications made by -that Contributor with its Contributor Version (or portions of such -combination). - -(c) the licenses granted in Sections 2.2(a) and 2.2(b) are effective -on the date Contributor first makes Commercial Use of the Covered -Code. - -(d) Notwithstanding Section 2.2(b) above, no patent license is -granted: 1) for any code that Contributor has deleted from the -Contributor Version; 2) separate from the Contributor Version; 3) for -infringements caused by: i) third party modifications of Contributor -Version or ii) the combination of Modifications made by that -Contributor with other software (except as part of the Contributor -Version) or other devices; or 4) under Patent Claims infringed by -Covered Code in the absence of Modifications made by that Contributor. - - -3. Distribution Obligations. - -3.1. Application of License. The Modifications which You create or to -which You contribute are governed by the terms of this License, -including without limitation Section 2.2. The Source Code version of -Covered Code may be distributed only under the terms of this License -or a future version of this License released under Section 6.1, and -You must include a copy of this License with every copy of the Source -Code You distribute. You may not offer or impose any terms on any -Source Code version that alters or restricts the applicable version of -this License or the recipients' rights hereunder. However, You may -include an additional document offering the additional rights -described in Section 3.5. - -3.2. Availability of Source Code. Any Modification which You create -or to which You contribute must be made available in Source Code form -under the terms of this License either on the same media as an -Executable version or via an accepted Electronic Distribution -Mechanism to anyone to whom you made an Executable version available; -and if made available via Electronic Distribution Mechanism, must -remain available for at least twelve (12) months after the date it -initially became available, or at least six (6) months after a -subsequent version of that particular Modification has been made -available to such recipients. You are responsible for ensuring that -the Source Code version remains available even if the Electronic -Distribution Mechanism is maintained by a third party. - -3.3. Description of Modifications. You must cause all Covered Code to -which You contribute to contain a file documenting the changes You -made to create that Covered Code and the date of any change. You must -include a prominent statement that the Modification is derived, -directly or indirectly, from Original Code provided by the Initial -Developer and including the name of the Initial Developer in (a) the -Source Code, and (b) in any notice in an Executable version or related -documentation in which You describe the origin or ownership of the -Covered Code. - -3.4. Intellectual Property Matters (a) Third Party Claims. If -Contributor has knowledge that a license under a third party's -intellectual property rights is required to exercise the rights -granted by such Contributor under Sections 2.1 or 2.2, Contributor -must include a text file with the Source Code distribution titled -"LEGAL" which describes the claim and the party making the claim in -sufficient detail that a recipient will know whom to contact. If -Contributor obtains such knowledge after the Modification is made -available as described in Section 3.2, Contributor shall promptly -modify the LEGAL file in all copies Contributor makes available -thereafter and shall take other steps (such as notifying appropriate -mailing lists or newsgroups) reasonably calculated to inform those who -received the Covered Code that new knowledge has been obtained. - -(b) Contributor APIs. If Contributor's Modifications include an -application programming interface and Contributor has knowledge of -patent licenses which are reasonably necessary to implement that API, -Contributor must also include this information in the LEGAL file. - -(c) Representations. Contributor represents that, except as disclosed -pursuant to Section 3.4(a) above, Contributor believes that -Contributor's Modifications are Contributor's original creation(s) -and/or Contributor has sufficient rights to grant the rights conveyed -by this License. - - -3.5. Required Notices. You must duplicate the notice in Exhibit A in -each file of the Source Code. If it is not possible to put such -notice in a particular Source Code file due to its structure, then You -must include such notice in a location (such as a relevant directory) -where a user would be likely to look for such a notice. If You -created one or more Modification(s) You may add your name as a -Contributor to the notice described in Exhibit A. You must also -duplicate this License in any documentation for the Source Code where -You describe recipients' rights or ownership rights relating to -Covered Code. You may choose to offer, and to charge a fee for, -warranty, support, indemnity or liability obligations to one or more -recipients of Covered Code. However, You may do so only on Your own -behalf, and not on behalf of the Initial Developer or any -Contributor. You must make it absolutely clear than any such warranty, -support, indemnity or liability obligation is offered by You alone, -and You hereby agree to indemnify the Initial Developer and every -Contributor for any liability incurred by the Initial Developer or -such Contributor as a result of warranty, support, indemnity or -liability terms You offer. - -3.6. Distribution of Executable Versions. You may distribute Covered -Code in Executable form only if the requirements of Section 3.1-3.5 -have been met for that Covered Code, and if You include a notice -stating that the Source Code version of the Covered Code is available -under the terms of this License, including a description of how and -where You have fulfilled the obligations of Section 3.2. The notice -must be conspicuously included in any notice in an Executable version, -related documentation or collateral in which You describe recipients' -rights relating to the Covered Code. You may distribute the Executable -version of Covered Code or ownership rights under a license of Your -choice, which may contain terms different from this License, provided -that You are in compliance with the terms of this License and that the -license for the Executable version does not attempt to limit or alter -the recipient's rights in the Source Code version from the rights set -forth in this License. If You distribute the Executable version under -a different license You must make it absolutely clear that any terms -which differ from this License are offered by You alone, not by the -Initial Developer or any Contributor. You hereby agree to indemnify -the Initial Developer and every Contributor for any liability incurred -by the Initial Developer or such Contributor as a result of any such -terms You offer. - -3.7. Larger Works. You may create a Larger Work by combining Covered -Code with other code not governed by the terms of this License and -distribute the Larger Work as a single product. In such a case, You -must make sure the requirements of this License are fulfilled for the -Covered Code. - -4. Inability to Comply Due to Statute or Regulation. - -If it is impossible for You to comply with any of the terms of this -License with respect to some or all of the Covered Code due to -statute, judicial order, or regulation then You must: (a) comply with -the terms of this License to the maximum extent possible; and (b) -describe the limitations and the code they affect. Such description -must be included in the LEGAL file described in Section 3.4 and must -be included with all distributions of the Source Code. Except to the -extent prohibited by statute or regulation, such description must be -sufficiently detailed for a recipient of ordinary skill to be able to -understand it. - -5. Application of this License. - -This License applies to code to which the Initial Developer has -attached the notice in Exhibit A and to related Covered Code. - -6. Versions of the License. - -6.1. New Versions. Thomas Richter may publish revised and/or new -versions of the License from time to time. Each version will be given -a distinguishing version number. - -6.2. Effect of New Versions. Once Covered Code has been published -under a particular version of the License, You may always continue to -use it under the terms of that version. You may also choose to use -such Covered Code under the terms of any subsequent version of the -License published by Thomas Richter. No one other than Thomas Richter -has the right to modify the terms applicable to Covered Code created -under this License. - -6.3. Derivative Works. If You create or use a modified version of -this License (which you may only do in order to apply it to code which -is not already Covered Code governed by this License), You must (a) -rename Your license so that the phrases "TPL", "THOR Software", -"Thomas Richter" or any confusingly similar phrase do not appear in -your license (except to note that your license differs from this -License) and (b) otherwise make it clear that Your version of the -license contains terms which differ from the THOR Public -License. (Filling in the name of the Initial Developer, Original Code -or Contributor in the notice described in Exhibit A shall not of -themselves be deemed to be modifications of this License.) - -7. DISCLAIMER OF WARRANTY. - -COVERED CODE IS PROVIDED UNDER THIS LICENSE ON AN "AS IS" BASIS, -WITHOUT WARRANTY OF ANY KIND, EITHER EXPRESSED OR IMPLIED, INCLUDING, -WITHOUT LIMITATION, WARRANTIES THAT THE COVERED CODE IS FREE OF -DEFECTS, MERCHANTABLE, FIT FOR A PARTICULAR PURPOSE OR -NON-INFRINGING. THE ENTIRE RISK AS TO THE QUALITY AND PERFORMANCE OF -THE COVERED CODE IS WITH YOU. SHOULD ANY COVERED CODE PROVE DEFECTIVE -IN ANY RESPECT, YOU (NOT THE INITIAL DEVELOPER OR ANY OTHER -CONTRIBUTOR) ASSUME THE COST OF ANY NECESSARY SERVICING, REPAIR OR -CORRECTION. THIS DISCLAIMER OF WARRANTY CONSTITUTES AN ESSENTIAL PART -OF THIS LICENSE. NO USE OF ANY COVERED CODE IS AUTHORIZED HEREUNDER -EXCEPT UNDER THIS DISCLAIMER. - -8. TERMINATION. - -8.1. This License and the rights granted hereunder will terminate -automatically if You fail to comply with terms herein and fail to cure -such breach within 30 days of becoming aware of the breach. All -sublicenses to the Covered Code which are properly granted shall -survive any termination of this License. Provisions which, by their -nature, must remain in effect beyond the termination of this License -shall survive. - -8.2. If You initiate litigation by asserting a patent infringement -claim (excluding declatory judgment actions) against Initial Developer -or a Contributor (the Initial Developer or Contributor against whom -You file such action is referred to as "Participant") alleging that: - -(a) such Participant's Contributor Version directly or indirectly -infringes any patent, then any and all rights granted by such -Participant to You under Sections 2.1 and/or 2.2 of this License -shall, upon 60 days notice from Participant terminate prospectively, -unless if within 60 days after receipt of notice You either: (i) agree -in writing to pay Participant a mutually agreeable reasonable royalty -for Your past and future use of Modifications made by such -Participant, or (ii) withdraw Your litigation claim with respect to -the Contributor Version against such Participant. If within 60 days -of notice, a reasonable royalty and payment arrangement are not -mutually agreed upon in writing by the parties or the litigation claim -is not withdrawn, the rights granted by Participant to You under -Sections 2.1 and/or 2.2 automatically terminate at the expiration of -the 60 day notice period specified above. - -(b) any software, hardware, or device, other than such Participant's -Contributor Version, directly or indirectly infringes any patent, then -any rights granted to You by such Participant under Sections 2.1(b) -and 2.2(b) are revoked effective as of the date You first made, used, -sold, distributed, or had made, Modifications made by that -Participant. - -8.3. If You assert a patent infringement claim against Participant -alleging that such Participant's Contributor Version directly or -indirectly infringes any patent where such claim is resolved (such as -by license or settlement) prior to the initiation of patent -infringement litigation, then the reasonable value of the licenses -granted by such Participant under Sections 2.1 or 2.2 shall be taken -into account in determining the amount or value of any payment or -license. - -8.4. In the event of termination under Sections 8.1 or 8.2 above, all -end user license agreements (excluding distributors and resellers) -which have been validly granted by You or any distributor hereunder -prior to termination shall survive termination. - -9. LIMITATION OF LIABILITY. - -UNDER NO CIRCUMSTANCES AND UNDER NO LEGAL THEORY, WHETHER TORT -(INCLUDING NEGLIGENCE), CONTRACT, OR OTHERWISE, SHALL YOU, THE INITIAL -DEVELOPER, ANY OTHER CONTRIBUTOR, OR ANY DISTRIBUTOR OF COVERED CODE, -OR ANY SUPPLIER OF ANY OF SUCH PARTIES, BE LIABLE TO ANY PERSON FOR -ANY INDIRECT, SPECIAL, INCIDENTAL, OR CONSEQUENTIAL DAMAGES OF ANY -CHARACTER INCLUDING, WITHOUT LIMITATION, DAMAGES FOR LOSS OF GOODWILL, -WORK STOPPAGE, COMPUTER FAILURE OR MALFUNCTION, OR ANY AND ALL OTHER -COMMERCIAL DAMAGES OR LOSSES, EVEN IF SUCH PARTY SHALL HAVE BEEN -INFORMED OF THE POSSIBILITY OF SUCH DAMAGES. THIS LIMITATION OF -LIABILITY SHALL NOT APPLY TO LIABILITY FOR DEATH OR PERSONAL INJURY -RESULTING FROM SUCH PARTY'S NEGLIGENCE TO THE EXTENT APPLICABLE LAW -PROHIBITS SUCH LIMITATION. SOME JURISDICTIONS DO NOT ALLOW THE -EXCLUSION OR LIMITATION OF INCIDENTAL OR CONSEQUENTIAL DAMAGES, SO -THIS EXCLUSION AND LIMITATION MAY NOT APPLY TO YOU. - -10. U.S. GOVERNMENT END USERS. - -The Covered Code is a "commercial item," as that term is defined in 48 -C.F.R. 2.101 (Oct. 1995), consisting of "commercial computer software" -and "commercial computer software documentation," as such terms are -used in 48 C.F.R. 12.212 (Sept. 1995). Consistent with 48 -C.F.R. 12.212 and 48 C.F.R. 227.7202-1 through 227.7202-4 (June 1995), -all U.S. Government End Users acquire Covered Code with only those -rights set forth herein. - -11. MISCELLANEOUS. - -This License represents the complete agreement concerning subject -matter hereof. If any provision of this License is held to be -unenforceable, such provision shall be reformed only to the extent -necessary to make it enforceable. This License shall be governed by -German law provisions (except to the extent applicable law, if any, -provides otherwise), excluding its conflict-of-law provisions. With -respect to disputes in which at least one party is a citizen of, or an -entity chartered or registered to do business in Federal Republic of -Germany, any litigation relating to this License shall be subject to -the jurisdiction of the Federal Courts of the Federal Republic of -Germany, with the losing party responsible for costs, including -without limitation, court costs and reasonable attorneys' fees and -expenses. Any law or regulation which provides that the language of a -contract shall be construed against the drafter shall not apply to -this License. - -12. RESPONSIBILITY FOR CLAIMS. - -As between Initial Developer and the Contributors, each party is -responsible for claims and damages arising, directly or indirectly, -out of its utilization of rights under this License and You agree to -work with Initial Developer and Contributors to distribute such -responsibility on an equitable basis. Nothing herein is intended or -shall be deemed to constitute any admission of liability. - -13. MULTIPLE-LICENSED CODE. - -Initial Developer may designate portions of the Covered Code as -Multiple-Licensed. Multiple-Licensed means that the Initial Developer -permits you to utilize portions of the Covered Code under Your choice -of the TPL or the alternative licenses, if any, specified by the -Initial Developer in the file described in Exhibit A. - - -EXHIBIT A - THOR Public License. - -The contents of this file are subject to the THOR Public License -Version 1.0 (the "License"); you may not use this file except in -compliance with the License. - -Software distributed under the License is distributed on an "AS IS" -basis, WITHOUT WARRANTY OF ANY KIND, either express or implied. See -the License for the specificlanguage governing rights and limitations -under the License. - -The Original Code is ______________________________________. - -The Initial Developer of the Original Code is _____________. - -Portions created by ______________________ are -Copyright (C) ______ _______________________. - -All Rights Reserved. - -Contributor(s): ______________________________________. - -Alternatively, the contents of this file may be used under the terms -of the _____ license (the [___] License), in which case the provisions -of [______] License are applicable instead of those above. If you -wish to allow use of your version of this file only under the terms of -the [____] License and not to allow others to use your version of this -file under the TPL, indicate your decision by deleting the provisions -above and replace them with the notice and other provisions required -by the [___] License. If you do not delete the provisions above, a -recipient may use your version of this file under either the TPL or -the [___] License." - -[NOTE: The text of this Exhibit A may differ slightly from the text of -the notices in the Source Code files of the Original Code. You should -use the text of this Exhibit A rather than the text found in the -Original Code Source Code for Your Modifications.] diff --git a/options/license/UCAR b/options/license/UCAR deleted file mode 100644 index 36e1810283ee7..0000000000000 --- a/options/license/UCAR +++ /dev/null @@ -1,32 +0,0 @@ -Copyright 2014 University Corporation for Atmospheric Research and contributors. -All rights reserved. - -This software was developed by the Unidata Program Center of the -University Corporation for Atmospheric Research (UCAR) -. - -Redistribution and use in source and binary forms, with or without modification, -are permitted provided that the following conditions are met: - - 1) Redistributions of source code must retain the above copyright notice, - this list of conditions and the following disclaimer. - 2) Redistributions in binary form must reproduce the above copyright notice, - this list of conditions and the following disclaimer in the documentation - and/or other materials provided with the distribution. - 3) Neither the names of the development group, the copyright holders, nor the - names of contributors may be used to endorse or promote products derived - from this software without specific prior written permission. - 4) This license shall terminate automatically and you may no longer exercise - any of the rights granted to you by this license as of the date you - commence an action, including a cross-claim or counterclaim, against - the copyright holders or any contributor alleging that this software - infringes a patent. This termination provision shall not apply for an - action alleging patent infringement by combinations of this software with - other software or hardware. - -THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR -IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY, FITNESS -FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE CONTRIBUTORS -OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER LIABILITY, -WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM, OUT OF OR IN -CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS WITH THE SOFTWARE. diff --git a/options/license/snprintf b/options/license/snprintf deleted file mode 100644 index 9e4ae73daaea8..0000000000000 --- a/options/license/snprintf +++ /dev/null @@ -1,3 +0,0 @@ -Copyright Patrick Powell 1995 - -This code is based on code written by Patrick Powell (papowell@astart.com) It may be used for any purpose as long as this notice remains intact on all source code distributions diff --git a/options/license/w3m b/options/license/w3m deleted file mode 100644 index 37081007bf3f0..0000000000000 --- a/options/license/w3m +++ /dev/null @@ -1,11 +0,0 @@ -(C) Copyright 1994-2002 by Akinori Ito -(C) Copyright 2002-2011 by Akinori Ito, Hironori Sakamoto, Fumitoshi Ukai - -Use, modification and redistribution of this software is hereby granted, -provided that this entire copyright notice is included on any copies of -this software and applications and derivations thereof. - -This software is provided on an "as is" basis, without warranty of any -kind, either expressed or implied, as to any matter including, but not -limited to warranty of fitness of purpose, or merchantability, or -results obtained from use of this software. diff --git a/options/license/xlock b/options/license/xlock deleted file mode 100644 index 39ccda0b4d4ce..0000000000000 --- a/options/license/xlock +++ /dev/null @@ -1,14 +0,0 @@ -Copyright (c) 1990 by Sun Microsystems, Inc. -Author: Patrick J. Naughton naughton@wind.sun.com - -Permission to use, copy, modify, and distribute this software and its -documentation for any purpose and without fee is hereby granted, -provided that the above copyright notice appear in all copies and -that both that copyright notice and this permission notice appear in -supporting documentation. - -This file is provided AS IS with no warranties of any kind. The author -shall have no liability with respect to the infringement of copyrights, -trade secrets or any patents by this file or any part thereof. In no event -will the author be liable for any lost revenue or profits or other special, -indirect and consequential damages. From 99c2b4b98c4ce50e1591c86d048393a51ecf80b4 Mon Sep 17 00:00:00 2001 From: Andrew Thornton Date: Sun, 26 Feb 2023 09:47:41 +0000 Subject: [PATCH 14/15] add actions job queue name Signed-off-by: Andrew Thornton --- modules/queue/setting.go | 2 ++ services/actions/init.go | 2 +- 2 files changed, 3 insertions(+), 1 deletion(-) diff --git a/modules/queue/setting.go b/modules/queue/setting.go index 7e95c9b4cb3e7..fc173fccef58f 100644 --- a/modules/queue/setting.go +++ b/modules/queue/setting.go @@ -24,6 +24,7 @@ const ( RepoArchiveQueueName UniqueQueueName = "repo-archive" PRAutoMergeQueueName UniqueQueueName = "pr_auto_merge" WebhookDeliveryQueueName UniqueQueueName = "webhook_sender" + ActionsJobQueueName UniqueQueueName = "actions_ready_job" ) // KnownUniqueQueueNames represents the list of expected unique queues @@ -33,6 +34,7 @@ var KnownUniqueQueueNames = []UniqueQueueName{ MirrorQueueName, PRPatchQueueName, RepoArchiveQueueName, + ActionsJobQueueName, } // QueueName represents an expected name for Queue diff --git a/services/actions/init.go b/services/actions/init.go index 3fd03eeb6f26c..5e762910e8c3c 100644 --- a/services/actions/init.go +++ b/services/actions/init.go @@ -15,7 +15,7 @@ func Init() { return } - jobEmitterQueue = queue.CreateUniqueQueue("actions_ready_job", jobEmitterQueueHandle, new(jobUpdate)) + jobEmitterQueue = queue.CreateUniqueQueue(queue.ActionsJobQueueName, jobEmitterQueueHandle, new(jobUpdate)) go graceful.GetManager().RunWithShutdownFns(jobEmitterQueue.Run) notification.RegisterNotifier(NewNotifier()) From 71e16d6df481928f64d291bcb7746ffa19275d36 Mon Sep 17 00:00:00 2001 From: Andrew Thornton Date: Sun, 26 Feb 2023 12:56:31 +0000 Subject: [PATCH 15/15] restore licenses deleted by mistake Signed-off-by: Andrew Thornton --- options/license/AdaCore-doc | 1 + options/license/Autoconf-exception-generic | 4 + options/license/Autoconf-exception-macro | 12 + options/license/BSD-4.3RENO | 9 + options/license/BSD-4.3TAHOE | 11 + .../license/BSD-Advertising-Acknowledgement | 37 ++ .../license/BSD-Attribution-HPND-disclaimer | 37 ++ options/license/Brian-Gladman-3-Clause | 26 + options/license/CC-BY-NC-SA-2.0-DE | 85 ++++ options/license/CFITSIO | 7 + options/license/CMU-Mach | 22 + options/license/Clips | 15 + options/license/Cornell-Lossless-JPEG | 20 + options/license/GNAT-exception | 6 + options/license/HP-1986 | 10 + options/license/HPND-Markus-Kuhn | 3 + .../license/HPND-sell-variant-MIT-disclaimer | 20 + options/license/IEC-Code-Components-EULA | 37 ++ options/license/JPL-image | 21 + options/license/Kazlib | 4 + options/license/Martin-Birgmeier | 5 + options/license/OFFIS | 22 + options/license/OpenPBS-2.3 | 76 +++ options/license/QPL-1.0-INRIA-2004 | 102 ++++ options/license/QPL-1.0-INRIA-2004-exception | 5 + options/license/SWI-exception | 6 + options/license/SunPro | 6 + options/license/TPL-1.0 | 475 ++++++++++++++++++ options/license/UCAR | 32 ++ options/license/snprintf | 3 + options/license/w3m | 11 + options/license/xlock | 14 + 32 files changed, 1144 insertions(+) create mode 100644 options/license/AdaCore-doc create mode 100644 options/license/Autoconf-exception-generic create mode 100644 options/license/Autoconf-exception-macro create mode 100644 options/license/BSD-4.3RENO create mode 100644 options/license/BSD-4.3TAHOE create mode 100644 options/license/BSD-Advertising-Acknowledgement create mode 100644 options/license/BSD-Attribution-HPND-disclaimer create mode 100644 options/license/Brian-Gladman-3-Clause create mode 100644 options/license/CC-BY-NC-SA-2.0-DE create mode 100644 options/license/CFITSIO create mode 100644 options/license/CMU-Mach create mode 100644 options/license/Clips create mode 100644 options/license/Cornell-Lossless-JPEG create mode 100644 options/license/GNAT-exception create mode 100644 options/license/HP-1986 create mode 100644 options/license/HPND-Markus-Kuhn create mode 100644 options/license/HPND-sell-variant-MIT-disclaimer create mode 100644 options/license/IEC-Code-Components-EULA create mode 100644 options/license/JPL-image create mode 100644 options/license/Kazlib create mode 100644 options/license/Martin-Birgmeier create mode 100644 options/license/OFFIS create mode 100644 options/license/OpenPBS-2.3 create mode 100644 options/license/QPL-1.0-INRIA-2004 create mode 100644 options/license/QPL-1.0-INRIA-2004-exception create mode 100644 options/license/SWI-exception create mode 100644 options/license/SunPro create mode 100644 options/license/TPL-1.0 create mode 100644 options/license/UCAR create mode 100644 options/license/snprintf create mode 100644 options/license/w3m create mode 100644 options/license/xlock diff --git a/options/license/AdaCore-doc b/options/license/AdaCore-doc new file mode 100644 index 0000000000000..0a1dab1b2c305 --- /dev/null +++ b/options/license/AdaCore-doc @@ -0,0 +1 @@ +This document may be copied, in whole or in part, in any form or by any means, as is or with alterations, provided that (1) alterations are clearly marked as alterations and (2) this copyright notice is included unmodified in any copy. diff --git a/options/license/Autoconf-exception-generic b/options/license/Autoconf-exception-generic new file mode 100644 index 0000000000000..b39f82767343b --- /dev/null +++ b/options/license/Autoconf-exception-generic @@ -0,0 +1,4 @@ +As a special exception to the GNU General Public License, +if you distribute this file as part of a program that contains +a configuration script generated by Autoconf, you may include +it under the same distribution terms that you use for the rest of that program. diff --git a/options/license/Autoconf-exception-macro b/options/license/Autoconf-exception-macro new file mode 100644 index 0000000000000..8b5b4677f3eb0 --- /dev/null +++ b/options/license/Autoconf-exception-macro @@ -0,0 +1,12 @@ +As a special exception, the respective Autoconf Macro's copyright owner +gives unlimited permission to copy, distribute and modify the configure +scripts that are the output of Autoconf when processing the Macro. You +need not follow the terms of the GNU General Public License when using +or distributing such scripts, even though portions of the text of the +Macro appear in them. The GNU General Public License (GPL) does govern +all other use of the material that constitutes the Autoconf Macro. + +This special exception to the GPL applies to versions of the Autoconf +Macro released by the Autoconf Archive. When you make and distribute a +modified version of the Autoconf Macro, you may extend this special +exception to the GPL to apply to your modified version as well. diff --git a/options/license/BSD-4.3RENO b/options/license/BSD-4.3RENO new file mode 100644 index 0000000000000..c05b03cc0f693 --- /dev/null +++ b/options/license/BSD-4.3RENO @@ -0,0 +1,9 @@ +Copyright (c) 1987 Regents of the University of California. +All rights reserved. + +Redistribution and use in source and binary forms are permitted +provided that this notice is preserved and that due credit is given +to the University of California at Berkeley. The name of the University +may not be used to endorse or promote products derived from this +software without specific written prior permission. This software +is provided ``as is'' without express or implied warranty. diff --git a/options/license/BSD-4.3TAHOE b/options/license/BSD-4.3TAHOE new file mode 100644 index 0000000000000..413098d93c01d --- /dev/null +++ b/options/license/BSD-4.3TAHOE @@ -0,0 +1,11 @@ +Copyright (c) 1987 Regents of the University of California. All rights reserved. + +Redistribution and use in source and binary forms are permitted provided +that the above copyright notice and this paragraph are duplicated in all +such forms and that any documentation, advertising materials, and other +materials related to such distribution and use acknowledge that the software +was developed by the University of California, Berkeley. The name of the +University may not be used to endorse or promote products derived from this +software without specific prior written permission. THIS SOFTWARE IS PROVIDED +``AS IS'' AND WITHOUT ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, WITHOUT +LIMITATION, THE IMPLIED WARRANTIES OF MERCHANTIBILITY AND FITNESS FOR A PARTICULAR PURPOSE. diff --git a/options/license/BSD-Advertising-Acknowledgement b/options/license/BSD-Advertising-Acknowledgement new file mode 100644 index 0000000000000..cedb72e6774f4 --- /dev/null +++ b/options/license/BSD-Advertising-Acknowledgement @@ -0,0 +1,37 @@ +Copyright (c) 2001 David Giffin. +All rights reserved. + +Redistribution and use in source and binary forms, with or without +modification, are permitted provided that the following conditions +are met: + +1. Redistributions of source code must retain the above copyright +notice, this list of conditions and the following disclaimer. + +2. Redistributions in binary form must reproduce the above copyright +notice, this list of conditions and the following disclaimer in +the documentation and/or other materials provided with the +distribution. + +3. All advertising materials mentioning features or use of this +software must display the following acknowledgment: +"This product includes software developed by +David Giffin ." + +4. Redistributions of any form whatsoever must retain the following +acknowledgment: +"This product includes software developed by +David Giffin ." + +THIS SOFTWARE IS PROVIDED BY DAVID GIFFIN ``AS IS'' AND ANY +EXPRESSED OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE +IMPLIED WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR +PURPOSE ARE DISCLAIMED. IN NO EVENT SHALL DAVID GIFFIN OR +ITS CONTRIBUTORS BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL, +SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT +NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; +LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) +HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, +STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) +ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED +OF THE POSSIBILITY OF SUCH DAMAGE. diff --git a/options/license/BSD-Attribution-HPND-disclaimer b/options/license/BSD-Attribution-HPND-disclaimer new file mode 100644 index 0000000000000..1272e1fe26a22 --- /dev/null +++ b/options/license/BSD-Attribution-HPND-disclaimer @@ -0,0 +1,37 @@ +Copyright (c) 1998-2003 Carnegie Mellon University. All rights reserved. + +Redistribution and use in source and binary forms, with or without +modification, are permitted provided that the following conditions +are met: + +1. Redistributions of source code must retain the above copyright + notice, this list of conditions and the following disclaimer. + +2. Redistributions in binary form must reproduce the above copyright + notice, this list of conditions and the following disclaimer in + the documentation and/or other materials provided with the + distribution. + +3. The name "Carnegie Mellon University" must not be used to + endorse or promote products derived from this software without + prior written permission. For permission or any other legal + details, please contact + Office of Technology Transfer + Carnegie Mellon University + 5000 Forbes Avenue + Pittsburgh, PA 15213-3890 + (412) 268-4387, fax: (412) 268-7395 + tech-transfer@andrew.cmu.edu + +4. Redistributions of any form whatsoever must retain the following + acknowledgment: + "This product includes software developed by Computing Services + at Carnegie Mellon University (http://www.cmu.edu/computing/)." + +CARNEGIE MELLON UNIVERSITY DISCLAIMS ALL WARRANTIES WITH REGARD TO +THIS SOFTWARE, INCLUDING ALL IMPLIED WARRANTIES OF MERCHANTABILITY +AND FITNESS, IN NO EVENT SHALL CARNEGIE MELLON UNIVERSITY BE LIABLE +FOR ANY SPECIAL, INDIRECT OR CONSEQUENTIAL DAMAGES OR ANY DAMAGES +WHATSOEVER RESULTING FROM LOSS OF USE, DATA OR PROFITS, WHETHER IN +AN ACTION OF CONTRACT, NEGLIGENCE OR OTHER TORTIOUS ACTION, ARISING +OUT OF OR IN CONNECTION WITH THE USE OR PERFORMANCE OF THIS SOFTWARE. diff --git a/options/license/Brian-Gladman-3-Clause b/options/license/Brian-Gladman-3-Clause new file mode 100644 index 0000000000000..984c95e3e86a9 --- /dev/null +++ b/options/license/Brian-Gladman-3-Clause @@ -0,0 +1,26 @@ +Copyright (c) 2003, Dr Brian Gladman, Worcester, UK. All rights reserved. + +LICENSE TERMS + +The free distribution and use of this software in both source and binary +form is allowed (with or without changes) provided that: + + 1. distributions of this source code include the above copyright + notice, this list of conditions and the following disclaimer; + + 2. distributions in binary form include the above copyright + notice, this list of conditions and the following disclaimer + in the documentation and/or other associated materials; + + 3. the copyright holder's name is not used to endorse products + built using this software without specific written permission. + +ALTERNATIVELY, provided that this notice is retained in full, this product +may be distributed under the terms of the GNU General Public License (GPL), +in which case the provisions of the GPL apply INSTEAD OF those given above. + +DISCLAIMER + +This software is provided 'as is' with no explicit or implied warranties +in respect of its properties, including, but not limited to, correctness +and/or fitness for purpose. diff --git a/options/license/CC-BY-NC-SA-2.0-DE b/options/license/CC-BY-NC-SA-2.0-DE new file mode 100644 index 0000000000000..ba4b72ac30ba1 --- /dev/null +++ b/options/license/CC-BY-NC-SA-2.0-DE @@ -0,0 +1,85 @@ +Creative Commons Namensnennung — Nicht-kommerziell — Weitergabe unter gleichen Bedingungen 2.0 + +CREATIVE COMMONS IST KEINE RECHTSANWALTSGESELLSCHAFT UND LEISTET KEINE RECHTSBERATUNG. DIE WEITERGABE DIESES LIZENZENTWURFES FÜHRT ZU KEINEM MANDATSVERHÄLTNIS. CREATIVE COMMONS ERBRINGT DIESE INFORMATIONEN OHNE GEWÄHR. CREATIVE COMMONS ÜBERNIMMT KEINE GEWÄHRLEISTUNG FÜR DIE GELIEFERTEN INFORMATIONEN UND SCHLIEßT DIE HAFTUNG FÜR SCHÄDEN AUS, DIE SICH AUS IHREM GEBRAUCH ERGEBEN. + +Lizenzvertrag + +DAS URHEBERRECHTLICH GESCHÜTZTE WERK ODER DER SONSTIGE SCHUTZGEGENSTAND (WIE UNTEN BESCHRIEBEN) WIRD UNTER DEN BEDINGUNGEN DIESER CREATIVE COMMONS PUBLIC LICENSE („CCPL“ ODER „LIZENZVERTRAG“) ZUR VERFÜGUNG GESTELLT. DER SCHUTZGEGENSTAND IST DURCH DAS URHEBERRECHT UND/ODER EINSCHLÄGIGE GESETZE GESCHÜTZT. + +DURCH DIE AUSÜBUNG EINES DURCH DIESEN LIZENZVERTRAG GEWÄHRTEN RECHTS AN DEM SCHUTZGEGENSTAND ERKLÄREN SIE SICH MIT DEN LIZENZBEDINGUNGEN RECHTSVERBINDLICH EINVERSTANDEN. DER LIZENZGEBER RÄUMT IHNEN DIE HIER BESCHRIEBENEN RECHTE UNTER DER VORAUSSETZUNGEIN, DASS SIE SICH MIT DIESEN VERTRAGSBEDINGUNGEN EINVERSTANDEN ERKLÄREN. + +1. Definitionen + + a. Unter einer „Bearbeitung“ wird eine Übersetzung oder andere Bearbeitung des Werkes verstanden, die Ihre persönliche geistige Schöpfung ist. Eine freie Benutzung des Werkes wird nicht als Bearbeitung angesehen. + + b. Unter den „Lizenzelementen“ werden die folgenden Lizenzcharakteristika verstanden, die vom Lizenzgeber ausgewählt und in der Bezeichnung der Lizenz genannt werden: „Namensnennung“, „Nicht-kommerziell“, „Weitergabe unter gleichen Bedingungen“. + + c. Unter dem „Lizenzgeber“ wird die natürliche oder juristische Person verstanden, die den Schutzgegenstand unter den Bedingungen dieser Lizenz anbietet. + + d. Unter einem „Sammelwerk“ wird eine Sammlung von Werken, Daten oder anderen unabhängigen Elementen verstanden, die aufgrund der Auswahl oder Anordnung der Elemente eine persönliche geistige Schöpfung ist. Darunter fallen auch solche Sammelwerke, deren Elemente systematisch oder methodisch angeordnet und einzeln mit Hilfe elektronischer Mittel oder auf andere Weise zugänglich sind (Datenbankwerke). Ein Sammelwerk wird im Zusammenhang mit dieser Lizenz nicht als Bearbeitung (wie oben beschrieben) angesehen. + + e. Mit „SIE“ und „Ihnen“ ist die natürliche oder juristische Person gemeint, die die durch diese Lizenz gewährten Nutzungsrechte ausübt und die zuvor die Bedingungen dieser Lizenz im Hinblick auf das Werk nicht verletzt hat, oder die die ausdrückliche Erlaubnis des Lizenzgebers erhalten hat, die durch diese Lizenz gewährten Nutzungsrechte trotz einer vorherigen Verletzung auszuüben. + + f. Unter dem „Schutzgegenstand“wird das Werk oder Sammelwerk oder das Schutzobjekt eines verwandten Schutzrechts, das Ihnen unter den Bedingungen dieser Lizenz angeboten wird, verstanden + + g. Unter dem „Urheber“ wird die natürliche Person verstanden, die das Werk geschaffen hat. + + h. Unter einem „verwandten Schutzrecht“ wird das Recht an einem anderen urheberrechtlichen Schutzgegenstand als einem Werk verstanden, zum Beispiel einer wissenschaftlichen Ausgabe, einem nachgelassenen Werk, einem Lichtbild, einer Datenbank, einem Tonträger, einer Funksendung, einem Laufbild oder einer Darbietung eines ausübenden Künstlers. + + i. Unter dem „Werk“ wird eine persönliche geistige Schöpfung verstanden, die Ihnen unter den Bedingungen dieser Lizenz angeboten wird. + +2. Schranken des Urheberrechts. Diese Lizenz lässt sämtliche Befugnisse unberührt, die sich aus den Schranken des Urheberrechts,aus dem Erschöpfungsgrundsatz oder anderen Beschränkungen der Ausschließlichkeitsrechte des Rechtsinhabers ergeben. + +3. Lizenzierung. Unter den Bedingungen dieses Lizenzvertrages räumt Ihnen der Lizenzgeber ein lizenzgebührenfreies, räumlich und zeitlich (für die Dauer des Urheberrechts oder verwandten Schutzrechts) unbeschränktes einfaches Nutzungsrecht ein, den Schutzgegenstand in der folgenden Art und Weise zu nutzen: + + a. den Schutzgegenstand in körperlicher Form zu verwerten, insbesondere zu vervielfältigen, zu verbreiten und auszustellen; + + b. den Schutzgegenstand in unkörperlicher Form öffentlich wiederzugeben, insbesondere vorzutragen, aufzuführen und vorzuführen, öffentlich zugänglich zu machen, zu senden, durch Bild- und Tonträger wiederzugeben sowie Funksendungen und öffentliche Zugänglichmachungen wiederzugeben; + + c. den Schutzgegenstand auf Bild- oder Tonträger aufzunehmen, Lichtbilder davon herzustellen, weiterzusenden und in dem in a. und b. genannten Umfang zu verwerten; + + d. den Schutzgegenstand zu bearbeiten oder in anderer Weise umzugestalten und die Bearbeitungen zu veröffentlichen und in dem in a. bis c. genannten Umfang zu verwerten; + +Die genannten Nutzungsrechte können für alle bekannten Nutzungsarten ausgeübt werden. Die genannten Nutzungsrechte beinhalten das Recht, solche Veränderungen an dem Werk vorzunehmen, die technisch erforderlich sind, um die Nutzungsrechte für alle Nutzungsarten wahrzunehmen. Insbesondere sind davon die Anpassung an andere Medien und auf andere Dateiformate umfasst. + +4. Beschränkungen. Die Einräumung der Nutzungsrechte gemäß Ziffer 3 erfolgt ausdrücklich nur unter den folgenden Bedingungen: + + a. Sie dürfen den Schutzgegenstand ausschließlich unter den Bedingungen dieser Lizenz vervielfältigen, verbreiten oder öffentlich wiedergeben, und Sie müssen stets eine Kopie oder die vollständige Internetadresse in Form des Uniform-Resource-Identifier (URI) dieser Lizenz beifügen, wenn Sie den Schutzgegenstandvervielfältigen, verbreiten oder öffentlich wiedergeben. Sie dürfen keine Vertragsbedingungen anbieten oder fordern, die die Bedingungen dieser Lizenz oder die durch sie gewährten Rechte ändern oder beschränken. Sie dürfen den Schutzgegenstand nicht unterlizenzieren. Sie müssen alle Hinweise unverändert lassen, die auf diese Lizenz und den Haftungsausschluss hinweisen. Sie dürfen den Schutzgegenstand mit keinen technischen Schutzmaßnahmen versehen, die den Zugang oder den Gebrauch des Schutzgegenstandes in einer Weise kontrollieren, die mit den Bedingungen dieser Lizenz im Widerspruch stehen. Die genannten Beschränkungen gelten auch für den Fall, dass der Schutzgegenstand einen Bestandteil eines Sammelwerkes bildet; sie verlangen aber nicht, dass das Sammelwerk insgesamt zum Gegenstand dieser Lizenz gemacht wird. Wenn Sie ein Sammelwerk erstellen, müssen Sie - soweit dies praktikabel ist - auf die Mitteilung eines Lizenzgebers oder Urhebers hin aus dem Sammelwerk jeglichen Hinweis auf diesen Lizenzgeber oder diesen Urheber entfernen. Wenn Sie den Schutzgegenstand bearbeiten, müssen Sie - soweit dies praktikabel ist- auf die Aufforderung eines Rechtsinhabers hin von der Bearbeitung jeglichen Hinweis auf diesen Rechtsinhaber entfernen. + + b. Sie dürfen eine Bearbeitung ausschließlich unter den Bedingungen dieser Lizenz, einer späteren Version dieser Lizenz mit denselben Lizenzelementen wie diese Lizenz oder einer Creative Commons iCommons Lizenz, die dieselben Lizenzelemente wie diese Lizenz enthält (z.B. Namensnennung - Nicht-kommerziell - Weitergabe unter gleichen Bedingungen 2.0 Japan), vervielfältigen, verbreiten oder öffentlich wiedergeben. Sie müssen stets eine Kopie oder die Internetadresse in Form des Uniform-Resource-Identifier (URI) dieser Lizenz oder einer anderen Lizenz der im vorhergehenden Satz beschriebenen Art beifügen, wenn Sie die Bearbeitung vervielfältigen, verbreiten oder öffentlich wiedergeben. Sie dürfen keine Vertragsbedingungen anbieten oder fordern, die die Bedingungen dieser Lizenz oder die durch sie gewährten Rechte ändern oder beschränken, und Sie müssen alle Hinweise unverändert lassen, die auf diese Lizenz und den Haftungsausschluss hinweisen. Sie dürfen eine Bearbeitung nicht mit technischen Schutzmaßnahmen versehen, die den Zugang oder den Gebrauch der Bearbeitung in einer Weise kontrollieren, die mit den Bedingungen dieser Lizenz im Widerspruch stehen. Die genannten Beschränkungen gelten auch für eine Bearbeitung als Bestandteil eines Sammelwerkes; sie erfordern aber nicht, dass das Sammelwerk insgesamt zum Gegenstand dieser Lizenz gemacht wird. + + c. Sie dürfen die in Ziffer 3 gewährten Nutzungsrechte in keiner Weise verwenden, die hauptsächlich auf einen geschäftlichen Vorteil oder eine vertraglich geschuldete geldwerte Vergütung abzielt oder darauf gerichtet ist. Erhalten Sie im Zusammenhang mit der Einräumung der Nutzungsrechte ebenfalls einen Schutzgegenstand, ohne dass eine vertragliche Verpflichtung hierzu besteht, so wird dies nicht als geschäftlicher Vorteil oder vertraglich geschuldete geldwerte Vergütung angesehen, wenn keine Zahlung oder geldwerte Vergütung in Verbindung mit dem Austausch der Schutzgegenstände geleistet wird (z.B. File-Sharing). + + d. Wenn Sie den Schutzgegenstand oder eine Bearbeitung oder ein Sammelwerk vervielfältigen, verbreiten oder öffentlich wiedergeben, müssen Sie alle Urhebervermerke für den Schutzgegenstand unverändert lassen und die Urheberschaft oder Rechtsinhaberschaft in einer der von Ihnen vorgenommenen Nutzung angemessenen Form anerkennen, indem Sie den Namen (oder das Pseudonym, falls ein solches verwendet wird) des Urhebers oder Rechteinhabers nennen, wenn dieser angegeben ist. Dies gilt auch für den Titel des Schutzgegenstandes, wenn dieser angeben ist, sowie - in einem vernünftigerweise durchführbaren Umfang - für die mit dem Schutzgegenstand zu verbindende Internetadresse in Form des Uniform-Resource-Identifier (URI), wie sie der Lizenzgeber angegeben hat, sofern dies geschehen ist, es sei denn, diese Internetadresse verweist nicht auf den Urhebervermerk oder die Lizenzinformationen zu dem Schutzgegenstand. Bei einer Bearbeitung ist ein Hinweis darauf aufzuführen, in welcher Form der Schutzgegenstand in die Bearbeitung eingegangen ist (z.B. „Französische Übersetzung des ... (Werk) durch ... (Urheber)“ oder „Das Drehbuch beruht auf dem Werk des ... (Urheber)“). Ein solcher Hinweis kann in jeder angemessenen Weise erfolgen, wobei jedoch bei einer Bearbeitung, einer Datenbank oder einem Sammelwerk der Hinweis zumindest an gleicher Stelle und in ebenso auffälliger Weise zu erfolgen hat wie vergleichbare Hinweise auf andere Rechtsinhaber. + + e. Obwohl die gemäss Ziffer 3 gewährten Nutzungsrechte in umfassender Weise ausgeübt werden dürfen, findet diese Erlaubnis ihre gesetzliche Grenze in den Persönlichkeitsrechten der Urheber und ausübenden Künstler, deren berechtigte geistige und persönliche Interessen bzw. deren Ansehen oder Ruf nicht dadurch gefährdet werden dürfen, dass ein Schutzgegenstand über das gesetzlich zulässige Maß hinaus beeinträchtigt wird. + +5. Gewährleistung. Sofern dies von den Vertragsparteien nicht anderweitig schriftlich vereinbart,, bietet der Lizenzgeber keine Gewährleistung für die erteilten Rechte, außer für den Fall, dass Mängel arglistig verschwiegen wurden. Für Mängel anderer Art, insbesondere bei der mangelhaften Lieferung von Verkörperungen des Schutzgegenstandes, richtet sich die Gewährleistung nach der Regelung, die die Person, die Ihnen den Schutzgegenstand zur Verfügung stellt, mit Ihnen außerhalb dieser Lizenz vereinbart, oder - wenn eine solche Regelung nicht getroffen wurde - nach den gesetzlichen Vorschriften. + +6. Haftung. Über die in Ziffer 5 genannte Gewährleistung hinaus haftet Ihnen der Lizenzgeber nur für Vorsatz und grobe Fahrlässigkeit. + +7. Vertragsende + + a. Dieser Lizenzvertrag und die durch ihn eingeräumten Nutzungsrechte enden automatisch bei jeder Verletzung der Vertragsbedingungen durch Sie. Für natürliche und juristische Personen, die von Ihnen eine Bearbeitung, eine Datenbank oder ein Sammelwerk unter diesen Lizenzbedingungen erhalten haben, gilt die Lizenz jedoch weiter, vorausgesetzt, diese natürlichen oder juristischen Personen erfüllen sämtliche Vertragsbedingungen. Die Ziffern 1, 2, 5, 6, 7 und 8 gelten bei einer Vertragsbeendigung fort. + + b. Unter den oben genannten Bedingungen erfolgt die Lizenz auf unbegrenzte Zeit (für die Dauer des Schutzrechts). Dennoch behält sich der Lizenzgeber das Recht vor, den Schutzgegenstand unter anderen Lizenzbedingungen zu nutzen oder die eigene Weitergabe des Schutzgegenstandes jederzeit zu beenden, vorausgesetzt, dass solche Handlungen nicht dem Widerruf dieser Lizenz dienen (oder jeder anderen Lizenzierung, die auf Grundlage dieser Lizenz erfolgt ist oder erfolgen muss) und diese Lizenz wirksam bleibt, bis Sie unter den oben genannten Voraussetzungen endet. + +8. Schlussbestimmungen + + a. Jedes Mal, wenn Sie den Schutzgegenstand vervielfältigen, verbreiten oder öffentlich wiedergeben, bietet der Lizenzgeber dem Erwerber eine Lizenz für den Schutzgegenstand unter denselben Vertragsbedingungen an, unter denen er Ihnen die Lizenz eingeräumt hat. + + b. Jedes Mal, wenn Sie eine Bearbeitung vervielfältigen, verbreiten oder öffentlich wiedergeben, bietet der Lizenzgeber dem Erwerber eine Lizenz für den ursprünglichen Schutzgegenstand unter denselben Vertragsbedingungen an, unter denen er Ihnen die Lizenz eingeräumt hat. + + c. Sollte eine Bestimmung dieses Lizenzvertrages unwirksam sein, so wird die Wirksamkeit der übrigen Lizenzbestimmungen dadurch nicht berührt, und an die Stelle der unwirksamen Bestimmung tritt eine Ersatzregelung, die dem mit der unwirksamen Bestimmung angestrebten Zweck am nächsten kommt. + + d. Nichts soll dahingehend ausgelegt werden, dass auf eine Bestimmung dieses Lizenzvertrages verzichtet oder einer Vertragsverletzung zugestimmt wird, so lange ein solcher Verzicht oder eine solche Zustimmung nicht schriftlich vorliegen und von der verzichtenden oder zustimmenden Vertragspartei unterschrieben sind + + e. Dieser Lizenzvertrag stellt die vollständige Vereinbarung zwischen den Vertragsparteien hinsichtlich des Schutzgegenstandes dar. Es gibt keine weiteren ergänzenden Vereinbarungen oder mündlichen Abreden im Hinblick auf den Schutzgegenstand. Der Lizenzgeber ist an keine zusätzlichen Abreden gebunden, die aus irgendeiner Absprache mit Ihnen entstehen könnten. Der Lizenzvertrag kann nicht ohne eine übereinstimmende schriftliche Vereinbarung zwischen dem Lizenzgeber und Ihnen abgeändert werden. + + f. Auf diesen Lizenzvertrag findet das Recht der Bundesrepublik Deutschland Anwendung. + +CREATIVE COMMONS IST KEINE VERTRAGSPARTEI DIESES LIZENZVERTRAGES UND ÜBERNIMMT KEINERLEI GEWÄHRLEISTUNG FÜR DAS WERK. CREATIVE COMMONS IST IHNEN ODER DRITTEN GEGENÜBER NICHT HAFTBAR FÜR SCHÄDEN JEDWEDER ART. UNGEACHTET DER VORSTEHENDEN ZWEI (2) SÄTZE HAT CREATIVE COMMONS ALL RECHTE UND PFLICHTEN EINES LIZENSGEBERS, WENN SICH CREATIVE COMMONS AUSDRÜCKLICH ALS LIZENZGEBER BEZEICHNET. + +AUSSER FÜR DEN BESCHRÄNKTEN ZWECK EINES HINWEISES AN DIE ÖFFENTLICHKEIT, DASS DAS WERK UNTER DER CCPL LIZENSIERT WIRD, DARF KENIE VERTRAGSPARTEI DIE MARKE “CREATIVE COMMONS” ODER EINE ÄHNLICHE MARKE ODER DAS LOGO VON CREATIVE COMMONS OHNE VORHERIGE GENEHMIGUNG VON CREATIVE COMMONS NUTZEN. JEDE GESTATTETE NUTZUNG HAT IN ÜBREEINSTIMMUNG MIT DEN JEWEILS GÜLTIGEN NUTZUNGSBEDINGUNGEN FÜR MARKEN VON CREATIVE COMMONS ZU ERFOLGEN, WIE SIE AUF DER WEBSITE ODER IN ANDERER WEISE AUF ANFRAGE VON ZEIT ZU ZEIT ZUGÄNGLICH GEMACHT WERDEN. + +CREATIVE COMMONS KANN UNTER https://creativecommons.org KONTAKTIERT WERDEN. diff --git a/options/license/CFITSIO b/options/license/CFITSIO new file mode 100644 index 0000000000000..f2c502057266a --- /dev/null +++ b/options/license/CFITSIO @@ -0,0 +1,7 @@ +Copyright (Unpublished-all rights reserved under the copyright laws of the United States), U.S. Government as represented by the Administrator of the National Aeronautics and Space Administration. No copyright is claimed in the United States under Title 17, U.S. Code. + +Permission to freely use, copy, modify, and distribute this software and its documentation without fee is hereby granted, provided that this copyright notice and disclaimer of warranty appears in all copies. + +DISCLAIMER: + +THE SOFTWARE IS PROVIDED 'AS IS' WITHOUT ANY WARRANTY OF ANY KIND, EITHER EXPRESSED, IMPLIED, OR STATUTORY, INCLUDING, BUT NOT LIMITED TO, ANY WARRANTY THAT THE SOFTWARE WILL CONFORM TO SPECIFICATIONS, ANY IMPLIED WARRANTIES OF MERCHANTABILITY, FITNESS FOR A PARTICULAR PURPOSE, AND FREEDOM FROM INFRINGEMENT, AND ANY WARRANTY THAT THE DOCUMENTATION WILL CONFORM TO THE SOFTWARE, OR ANY WARRANTY THAT THE SOFTWARE WILL BE ERROR FREE. IN NO EVENT SHALL NASA BE LIABLE FOR ANY DAMAGES, INCLUDING, BUT NOT LIMITED TO, DIRECT, INDIRECT, SPECIAL OR CONSEQUENTIAL DAMAGES, ARISING OUT OF, RESULTING FROM, OR IN ANY WAY CONNECTED WITH THIS SOFTWARE, WHETHER OR NOT BASED UPON WARRANTY, CONTRACT, TORT , OR OTHERWISE, WHETHER OR NOT INJURY WAS SUSTAINED BY PERSONS OR PROPERTY OR OTHERWISE, AND WHETHER OR NOT LOSS WAS SUSTAINED FROM, OR AROSE OUT OF THE RESULTS OF, OR USE OF, THE SOFTWARE OR SERVICES PROVIDED HEREUNDER." diff --git a/options/license/CMU-Mach b/options/license/CMU-Mach new file mode 100644 index 0000000000000..1bb895d4eca77 --- /dev/null +++ b/options/license/CMU-Mach @@ -0,0 +1,22 @@ +Copyright (c) 1991,1990,1989 Carnegie Mellon University +All Rights Reserved. + +Permission to use, copy, modify and distribute this software and its +documentation is hereby granted, provided that both the copyright +notice and this permission notice appear in all copies of the +software, derivative works or modified versions, and any portions +thereof, and that both notices appear in supporting documentation. + +CARNEGIE MELLON ALLOWS FREE USE OF THIS SOFTWARE IN ITS "AS IS" +CONDITION. CARNEGIE MELLON DISCLAIMS ANY LIABILITY OF ANY KIND FOR +ANY DAMAGES WHATSOEVER RESULTING FROM THE USE OF THIS SOFTWARE. + +Carnegie Mellon requests users of this software to return to + + Software Distribution Coordinator or Software.Distribution@CS.CMU.EDU + School of Computer Science + Carnegie Mellon University + Pittsburgh PA 15213-3890 + +any improvements or extensions that they make and grant Carnegie Mellon +the rights to redistribute these changes. diff --git a/options/license/Clips b/options/license/Clips new file mode 100644 index 0000000000000..ff5afdd293138 --- /dev/null +++ b/options/license/Clips @@ -0,0 +1,15 @@ +Permission is hereby granted, free of charge, to any person obtaining +a copy of this software and associated documentation files (the +"Software"), to deal in the Software without restriction, including +without limitation the rights to use, copy, modify, merge, publish, +distribute, and/or sell copies of the Software, and to permit persons +to whom the Software is furnished to do so. + +THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS +OR IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF +MERCHANTABILITY, FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT +OF THIRD PARTY RIGHTS. IN NO EVENT SHALL THE AUTHORS BE LIABLE FOR ANY +CLAIM, OR ANY SPECIAL INDIRECT OR CONSEQUENTIAL DAMAGES, OR ANY DAMAGES +WHATSOEVER RESULTING FROM LOSS OF USE, DATA OR PROFITS, WHETHER IN AN +ACTION OF CONTRACT, NEGLIGENCE OR OTHER TORTIOUS ACTION, ARISING OUT OF +OR IN CONNECTION WITH THE USE OR PERFORMANCE OF THIS SOFTWARE. diff --git a/options/license/Cornell-Lossless-JPEG b/options/license/Cornell-Lossless-JPEG new file mode 100644 index 0000000000000..7d2d44394d273 --- /dev/null +++ b/options/license/Cornell-Lossless-JPEG @@ -0,0 +1,20 @@ +Copyright (c) 1993 Cornell University, Kongji Huang +All rights reserved. + +Permission to use, copy, modify, and distribute this software and its +documentation for any purpose, without fee, and without written +agreement is hereby granted, provided that the above copyright notice +and the following two paragraphs appear in all copies of this +software. + +IN NO EVENT SHALL THE CORNELL UNIVERSITY BE LIABLE TO ANY PARTY FOR +DIRECT, INDIRECT, SPECIAL, INCIDENTAL, OR CONSEQUENTIAL DAMAGES ARISING +OUT OF THE USE OF THIS SOFTWARE AND ITS DOCUMENTATION, EVEN IF CORNELL +UNIVERSITY HAS BEEN ADVISED OF THE POSSIBILITY OF SUCH DAMAGE. + +THE CORNELL UNIVERSITY SPECIFICALLY DISCLAIMS ANY WARRANTIES, +INCLUDING, BUT NOT LIMITED TO, THE IMPLIED WARRANTIES OF +MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE. THE SOFTWARE +PROVIDED HEREUNDER IS ON AN "AS IS" BASIS, AND CORNELL UNIVERSITY HAS +NO OBLIGATION TO PROVIDE MAINTENANCE, SUPPORT, UPDATES, ENHANCEMENTS, +OR MODIFICATIONS. diff --git a/options/license/GNAT-exception b/options/license/GNAT-exception new file mode 100644 index 0000000000000..2b5a96a62b08a --- /dev/null +++ b/options/license/GNAT-exception @@ -0,0 +1,6 @@ +As a special exception, if other files instantiate generics from this +unit, or you link this unit with other files to produce an executable, +this unit does not by itself cause the resulting executable to be +covered by the GNU General Public License. This exception does not +however invalidate any other reasons why the executable file might be +covered by the GNU Public License. diff --git a/options/license/HP-1986 b/options/license/HP-1986 new file mode 100644 index 0000000000000..35844cb4d852a --- /dev/null +++ b/options/license/HP-1986 @@ -0,0 +1,10 @@ +(c) Copyright 1986 HEWLETT-PACKARD COMPANY + +To anyone who acknowledges that this file is provided "AS IS" +without any express or implied warranty: permission to use, copy, +modify, and distribute this file for any purpose is hereby granted +without fee, provided that the above copyright notice and this notice +appears in all copies, and that the name of Hewlett-Packard Company +not be used in advertising or publicity pertaining to distribution +of the software without specific, written prior permission. Hewlett-Packard +Company makes no representations about the suitability of this software for any purpose. diff --git a/options/license/HPND-Markus-Kuhn b/options/license/HPND-Markus-Kuhn new file mode 100644 index 0000000000000..ca41db16188de --- /dev/null +++ b/options/license/HPND-Markus-Kuhn @@ -0,0 +1,3 @@ +Permission to use, copy, modify, and distribute this software +for any purpose and without fee is hereby granted. The author +disclaims all warranties with regard to this software. diff --git a/options/license/HPND-sell-variant-MIT-disclaimer b/options/license/HPND-sell-variant-MIT-disclaimer new file mode 100644 index 0000000000000..d4464e0c35cb9 --- /dev/null +++ b/options/license/HPND-sell-variant-MIT-disclaimer @@ -0,0 +1,20 @@ +by Jim Knoble + Copyright (C) 1999,2000,2001 Jim Knoble + + Permission to use, copy, modify, distribute, and sell this software + and its documentation for any purpose is hereby granted without fee, + provided that the above copyright notice appear in all copies and + that both that copyright notice and this permission notice appear in + supporting documentation. + ++------------+ +| Disclaimer | ++------------+ + + THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, + express or implied, including but not limited to the warranties of + merchantability, fitness for a particular purpose and + noninfringement. In no event shall the author(s) be liable for any + claim, damages or other liability, whether in an action of contract, + tort or otherwise, arising from, out of or in connection with the + software or the use or other dealings in the software. diff --git a/options/license/IEC-Code-Components-EULA b/options/license/IEC-Code-Components-EULA new file mode 100644 index 0000000000000..b74269afd9b91 --- /dev/null +++ b/options/license/IEC-Code-Components-EULA @@ -0,0 +1,37 @@ +IEC Code Components End-user licence agreement + +Code Components in IEC standards (International Standards, Technical Specifications or +Technical Reports) which have been identified and approved for licensing, are licensed subject to +the following conditions: + +- Redistributions of software must retain the Copyright Notice, this list of conditions and the +disclaimer below (“Disclaimer”). +- The software license extends to modifications permitted under the relevant IEC standard. +- The software license extends to clarifications and corrections approved by IEC. +- Neither the name of IEC, nor the names of specific contributors, may be used to endorse or +promote products derived from this software without specific prior written permission. The +relevant IEC standard may be referenced when claiming compliance with the relevant IEC +standard. +- The user of Code Components shall attribute each such Code Component to IEC and identify +the IEC standard from which it is taken. Such attribution (e.g., “This code was derived from IEC +[insert standard reference number:publication year] within modifications permitted in the +relevant IEC standard. Please reproduce this note if possible.”), may be placed in the code itself +or any other reasonable location. + +Code Components means components included in IEC standards that are intended to be directly +processed by a computer and also includes any text found between the markers and , or otherwise clearly labeled in this standard as a Code +Component. + +The Disclaimer is: +EACH OF THE CODE COMPONENTS IS PROVIDED BY THE COPYRIGHT HOLDERS AND +CONTRIBUTORS “AS IS” AND ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT +NOT LIMITED TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A +PARTICULAR PURPOSE ARE DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT OWNER +OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, +EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT LIMITED TO, +PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR +PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF +LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING +NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE OF THE CODE +COMPONENTS, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE. diff --git a/options/license/JPL-image b/options/license/JPL-image new file mode 100644 index 0000000000000..828b1b5424ec4 --- /dev/null +++ b/options/license/JPL-image @@ -0,0 +1,21 @@ +JPL Image Use Policy + +Unless otherwise noted, images and video on JPL public web sites (public sites ending with a jpl.nasa.gov address) may be used for any purpose without prior permission, subject to the special cases noted below. Publishers who wish to have authorization may print this page and retain it for their records; JPL does not issue image permissions on an image by image basis. + +By electing to download the material from this web site the user agrees: + +1. that Caltech makes no representations or warranties with respect to ownership of copyrights in the images, and does not represent others who may claim to be authors or owners of copyright of any of the images, and makes no warranties as to the quality of the images. Caltech shall not be responsible for any loss or expenses resulting from the use of the images, and you release and hold Caltech harmless from all liability arising from such use. +2. to use a credit line in connection with images. Unless otherwise noted in the caption information for an image, the credit line should be "Courtesy NASA/JPL-Caltech." +3. that the endorsement of any product or service by Caltech, JPL or NASA must not be claimed or implied. + +Special Cases: + +* Prior written approval must be obtained to use the NASA insignia logo (the blue "meatball" insignia), the NASA logotype (the red "worm" logo) and the NASA seal. These images may not be used by persons who are not NASA employees or on products (including Web pages) that are not NASA sponsored. In addition, no image may be used to explicitly or implicitly suggest endorsement by NASA, JPL or Caltech of commercial goods or services. Requests to use NASA logos may be directed to Bert Ulrich, Public Services Division, NASA Headquarters, Code POS, Washington, DC 20546, telephone (202) 358-1713, fax (202) 358-4331, email bert.ulrich@hq.nasa.gov. + +* Prior written approval must be obtained to use the JPL logo (stylized JPL letters in red or other colors). Requests to use the JPL logo may be directed to the Institutional Communications Office, email instcomm@jpl.nasa.gov. + +* If an image includes an identifiable person, using the image for commercial purposes may infringe that person's right of privacy or publicity, and permission should be obtained from the person. NASA and JPL generally do not permit likenesses of current employees to appear on commercial products. For more information, consult the NASA and JPL points of contact listed above. + +* JPL/Caltech contractors and vendors who wish to use JPL images in advertising or public relation materials should direct requests to the Institutional Communications Office, email instcomm@jpl.nasa.gov. + +* Some image and video materials on JPL public web sites are owned by organizations other than JPL or NASA. These owners have agreed to make their images and video available for journalistic, educational and personal uses, but restrictions are placed on commercial uses. To obtain permission for commercial use, contact the copyright owner listed in each image caption. Ownership of images and video by parties other than JPL and NASA is noted in the caption material with each image. diff --git a/options/license/Kazlib b/options/license/Kazlib new file mode 100644 index 0000000000000..714f2eabf9cc5 --- /dev/null +++ b/options/license/Kazlib @@ -0,0 +1,4 @@ +Copyright (C) 1999 Kaz Kylheku + +Free Software License: +All rights are reserved by the author, with the following exceptions: Permission is granted to freely reproduce and distribute this software, possibly in exchange for a fee, provided that this copyright notice appears intact. Permission is also granted to adapt this software to produce derivative works, as long as the modified versions carry this copyright notice and additional notices stating that the work has been modified. This source code may be translated into executable form and incorporated into proprietary software; there is no requirement for such software to contain a copyright notice related to this source. diff --git a/options/license/Martin-Birgmeier b/options/license/Martin-Birgmeier new file mode 100644 index 0000000000000..48d32f846e5b7 --- /dev/null +++ b/options/license/Martin-Birgmeier @@ -0,0 +1,5 @@ +Copyright (c) 1993 Martin Birgmeier All rights reserved. + +You may redistribute unmodified or modified versions of this source code provided that the above copyright notice and this and the following conditions are retained. + +This software is provided ``as is'', and comes with no warranties of any kind. I shall in no event be liable for anything that happens to anyone/anything when using this software. diff --git a/options/license/OFFIS b/options/license/OFFIS new file mode 100644 index 0000000000000..ad48f181c39bc --- /dev/null +++ b/options/license/OFFIS @@ -0,0 +1,22 @@ +Copyright (C) 1994-2001, OFFIS + +This software and supporting documentation were developed by + +Kuratorium OFFIS e.V. +Healthcare Information and Communication Systems +Escherweg 2 +D-26121 Oldenburg, Germany + +THIS SOFTWARE IS MADE AVAILABLE, AS IS, AND OFFIS MAKES NO WARRANTY +REGARDING THE SOFTWARE, ITS PERFORMANCE, ITS MERCHANTABILITY OR +FITNESS FOR ANY PARTICULAR USE, FREEDOM FROM ANY COMPUTER DISEASES OR +ITS CONFORMITY TO ANY SPECIFICATION. THE ENTIRE RISK AS TO QUALITY AND +PERFORMANCE OF THE SOFTWARE IS WITH THE USER. + +Copyright of the software and supporting documentation is, unless +otherwise stated, owned by OFFIS, and free access is hereby granted as +a license to use this software, copy this software and prepare +derivative works based upon this software. However, any distribution +of this software source code or supporting documentation or derivative +works (source code and supporting documentation) must include the +three paragraphs of this copyright notice. diff --git a/options/license/OpenPBS-2.3 b/options/license/OpenPBS-2.3 new file mode 100644 index 0000000000000..61f52c22021cc --- /dev/null +++ b/options/license/OpenPBS-2.3 @@ -0,0 +1,76 @@ + + OpenPBS (Portable Batch System) v2.3 Software License + +Copyright (c) 1999-2000 Veridian Information Solutions, Inc. +All rights reserved. + +--------------------------------------------------------------------------- +For a license to use or redistribute the OpenPBS software under conditions +other than those described below, or to purchase support for this software, +please contact Veridian Systems, PBS Products Department ("Licensor") at: + + www.OpenPBS.org +1 650 967-4675 sales@OpenPBS.org + 877 902-4PBS (US toll-free) +--------------------------------------------------------------------------- + +This license covers use of the OpenPBS v2.3 software (the "Software") at +your site or location, and, for certain users, redistribution of the +Software to other sites and locations. Use and redistribution of +OpenPBS v2.3 in source and binary forms, with or without modification, +are permitted provided that all of the following conditions are met. +After December 31, 2001, only conditions 3-6 must be met: + +1. Commercial and/or non-commercial use of the Software is permitted + provided a current software registration is on file at www.OpenPBS.org. + If use of this software contributes to a publication, product, or + service, proper attribution must be given; see www.OpenPBS.org/credit.html + +2. Redistribution in any form is only permitted for non-commercial, + non-profit purposes. There can be no charge for the Software or any + software incorporating the Software. Further, there can be no + expectation of revenue generated as a consequence of redistributing + the Software. + +3. Any Redistribution of source code must retain the above copyright notice + and the acknowledgment contained in paragraph 6, this list of conditions + and the disclaimer contained in paragraph 7. + +4. Any Redistribution in binary form must reproduce the above copyright + notice and the acknowledgment contained in paragraph 6, this list of + conditions and the disclaimer contained in paragraph 7 in the + documentation and/or other materials provided with the distribution. + +5. Redistributions in any form must be accompanied by information on how to + obtain complete source code for the OpenPBS software and any + modifications and/or additions to the OpenPBS software. The source code + must either be included in the distribution or be available for no more + than the cost of distribution plus a nominal fee, and all modifications + and additions to the Software must be freely redistributable by any party + (including Licensor) without restriction. + +6. All advertising materials mentioning features or use of the Software must + display the following acknowledgment: + + "This product includes software developed by NASA Ames Research Center, + Lawrence Livermore National Laboratory, and Veridian Information Solutions, + Inc. Visit www.OpenPBS.org for OpenPBS software support, + products, and information." + +7. DISCLAIMER OF WARRANTY + +THIS SOFTWARE IS PROVIDED "AS IS" WITHOUT WARRANTY OF ANY KIND. ANY EXPRESS +OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED WARRANTIES +OF MERCHANTABILITY, FITNESS FOR A PARTICULAR PURPOSE, AND NON-INFRINGEMENT +ARE EXPRESSLY DISCLAIMED. + +IN NO EVENT SHALL VERIDIAN CORPORATION, ITS AFFILIATED COMPANIES, OR THE +U.S. GOVERNMENT OR ANY OF ITS AGENCIES BE LIABLE FOR ANY DIRECT OR INDIRECT, +INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT +LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, +OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF +LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING +NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, +EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE. + +This license will be governed by the laws of the Commonwealth of Virginia, +without reference to its choice of law rules. diff --git a/options/license/QPL-1.0-INRIA-2004 b/options/license/QPL-1.0-INRIA-2004 new file mode 100644 index 0000000000000..45d946e2e239a --- /dev/null +++ b/options/license/QPL-1.0-INRIA-2004 @@ -0,0 +1,102 @@ + THE Q PUBLIC LICENSE version 1.0 + + Copyright (C) 1999 Troll Tech AS, Norway. + Everyone is permitted to copy and + distribute this license document. + +The intent of this license is to establish freedom to share and change +the software regulated by this license under the open source model. + +This license applies to any software containing a notice placed by the +copyright holder saying that it may be distributed under the terms of +the Q Public License version 1.0. Such software is herein referred to +as the Software. This license covers modification and distribution of +the Software, use of third-party application programs based on the +Software, and development of free software which uses the Software. + + Granted Rights + +1. You are granted the non-exclusive rights set forth in this license +provided you agree to and comply with any and all conditions in this +license. Whole or partial distribution of the Software, or software +items that link with the Software, in any form signifies acceptance of +this license. + +2. You may copy and distribute the Software in unmodified form +provided that the entire package, including - but not restricted to - +copyright, trademark notices and disclaimers, as released by the +initial developer of the Software, is distributed. + +3. You may make modifications to the Software and distribute your +modifications, in a form that is separate from the Software, such as +patches. The following restrictions apply to modifications: + + a. Modifications must not alter or remove any copyright notices + in the Software. + + b. When modifications to the Software are released under this + license, a non-exclusive royalty-free right is granted to the + initial developer of the Software to distribute your + modification in future versions of the Software provided such + versions remain available under these terms in addition to any + other license(s) of the initial developer. + +4. You may distribute machine-executable forms of the Software or +machine-executable forms of modified versions of the Software, +provided that you meet these restrictions: + + a. You must include this license document in the distribution. + + b. You must ensure that all recipients of the machine-executable + forms are also able to receive the complete machine-readable + source code to the distributed Software, including all + modifications, without any charge beyond the costs of data + transfer, and place prominent notices in the distribution + explaining this. + + c. You must ensure that all modifications included in the + machine-executable forms are available under the terms of this + license. + +5. You may use the original or modified versions of the Software to +compile, link and run application programs legally developed by you or +by others. + +6. You may develop application programs, reusable components and other +software items that link with the original or modified versions of the +Software. These items, when distributed, are subject to the following +requirements: + + a. You must ensure that all recipients of machine-executable + forms of these items are also able to receive and use the + complete machine-readable source code to the items without any + charge beyond the costs of data transfer. + + b. You must explicitly license all recipients of your items to + use and re-distribute original and modified versions of the + items in both machine-executable and source code forms. The + recipients must be able to do so without any charges whatsoever, + and they must be able to re-distribute to anyone they choose. + + c. If the items are not available to the general public, and the + initial developer of the Software requests a copy of the items, + then you must supply one. + + Limitations of Liability + +In no event shall the initial developers or copyright holders be +liable for any damages whatsoever, including - but not restricted to - +lost revenue or profits or other direct, indirect, special, incidental +or consequential damages, even if they have been advised of the +possibility of such damages, except to the extent invariable law, if +any, provides otherwise. + + No Warranty + +The Software and this license document are provided AS IS with NO +WARRANTY OF ANY KIND, INCLUDING THE WARRANTY OF DESIGN, +MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE. + + Choice of Law + +This license is governed by the Laws of France. diff --git a/options/license/QPL-1.0-INRIA-2004-exception b/options/license/QPL-1.0-INRIA-2004-exception new file mode 100644 index 0000000000000..2418a26377cdb --- /dev/null +++ b/options/license/QPL-1.0-INRIA-2004-exception @@ -0,0 +1,5 @@ +As a special exception to the Q Public Licence, you may develop +application programs, reusable components and other software items +that link with the original or modified versions of the Software +and are not made available to the general public, without any of the +additional requirements listed in clause 6c of the Q Public licence. diff --git a/options/license/SWI-exception b/options/license/SWI-exception new file mode 100644 index 0000000000000..9ccfb9b89cf8a --- /dev/null +++ b/options/license/SWI-exception @@ -0,0 +1,6 @@ +As a special exception, if you link this library with other files, +compiled with a Free Software compiler, to produce an executable, this +library does not by itself cause the resulting executable to be covered +by the GNU General Public License. This exception does not however +invalidate any other reasons why the executable file might be covered by +the GNU General Public License. diff --git a/options/license/SunPro b/options/license/SunPro new file mode 100644 index 0000000000000..1ccb78add07bb --- /dev/null +++ b/options/license/SunPro @@ -0,0 +1,6 @@ +Copyright (C) 1993 by Sun Microsystems, Inc. All rights reserved. + +Developed at SunSoft, a Sun Microsystems, Inc. business. +Permission to use, copy, modify, and distribute this +software is freely granted, provided that this notice +is preserved. diff --git a/options/license/TPL-1.0 b/options/license/TPL-1.0 new file mode 100644 index 0000000000000..1634db4912ed4 --- /dev/null +++ b/options/license/TPL-1.0 @@ -0,0 +1,475 @@ +THOR Public Licence (TPL) + +0. Notes of Origin + +0.1 As required by paragraph 6.3 of the "Mozilla Public Licence", +"MPL" in the following, it is hereby stated that this Licence +condition ("TPL") differs in the following items from the original +"Mozilla Public Licence" as provided by "Netscape Communications +Corporation": + +a) Paragraphs 6.2 and 6.3 of the MPL has been modified to bind licence +modifications to the Author of this Licence, Thomas Richter. + +b) Paragraph 11 has been modified to gover this Licence by German +law rather than Californian Law. + +c) The licence has been renamed to "TPL" and "THOR Public +Licence". All references towards "MPL" have been removed except in +section 0 to indicate the difference from "MPL". + +No other modifications have been made. + + +1. Definitions. + +1.0.1. "Commercial Use" means distribution or otherwise making the +Covered Code available to a third party. + +1.1. "Contributor" means each entity that creates or contributes to +the creation of Modifications. + +1.2. "Contributor Version" means the combination of the Original Code, +prior Modifications used by a Contributor, and the Modifications made +by that particular Contributor. + +1.3. "Covered Code" means the Original Code or Modifications or the +combination of the Original Code and Modifications, in each case +including portions thereof. + +1.4. "Electronic Distribution Mechanism" means a mechanism generally +accepted in the software development community for the electronic +transfer of data. + +1.5. "Executable" means Covered Code in any form other than Source +Code. + +1.6. "Initial Developer" means the individual or entity identified as +the Initial Developer in the Source Code notice required by Exhibit A. + +1.7. "Larger Work" means a work which combines Covered Code or +portions thereof with code not governed by the terms of this License. + +1.8. "License" means this document. + +1.8.1. "Licensable" means having the right to grant, to the maximum +extent possible, whether at the time of the initial grant or +subsequently acquired, any and all of the rights conveyed herein. + +1.9. "Modifications" means any addition to or deletion from the +substance or structure of either the Original Code or any previous +Modifications. When Covered Code is released as a series of files, a +Modification is: A. Any addition to or deletion from the contents of a +file containing Original Code or previous Modifications. + +B. Any new file that contains any part of the Original Code or +previous Modifications. + +1.10. "Original Code" means Source Code of computer software code +which is described in the Source Code notice required by Exhibit A as +Original Code, and which, at the time of its release under this +License is not already Covered Code governed by this License. + +1.10.1. "Patent Claims" means any patent claim(s), now owned or +hereafter acquired, including without limitation, method, process, and +apparatus claims, in any patent Licensable by grantor. + +1.11. "Source Code" means the preferred form of the Covered Code for +making modifications to it, including all modules it contains, plus +any associated interface definition files, scripts used to control +compilation and installation of an Executable, or source code +differential comparisons against either the Original Code or another +well known, available Covered Code of the Contributor's choice. The +Source Code can be in a compressed or archival form, provided the +appropriate decompression or de-archiving software is widely available +for no charge. + +1.12. "You" (or "Your") means an individual or a legal entity +exercising rights under, and complying with all of the terms of, this +License or a future version of this License issued under Section +6.1. For legal entities, "You" includes any entity which controls, is +controlled by, or is under common control with You. For purposes of +this definition, "control" means (a) the power, direct or indirect, to +cause the direction or management of such entity, whether by contract +or otherwise, or (b) ownership of more than fifty percent (50%) of the +outstanding shares or beneficial ownership of such entity. + +2. Source Code License. + +2.1. The Initial Developer Grant. The Initial Developer hereby grants +You a world-wide, royalty-free, non-exclusive license, subject to +third party intellectual property claims: (a) under intellectual +property rights (other than patent or trademark) Licensable by Initial +Developer to use, reproduce, modify, display, perform, sublicense and +distribute the Original Code (or portions thereof) with or without +Modifications, and/or as part of a Larger Work; and + +(b) under Patents Claims infringed by the making, using or selling of +Original Code, to make, have made, use, practice, sell, and offer for +sale, and/or otherwise dispose of the Original Code (or portions +thereof). + +(c) the licenses granted in this Section 2.1(a) and (b) are effective +on the date Initial Developer first distributes Original Code under +the terms of this License. + +(d) Notwithstanding Section 2.1(b) above, no patent license is +granted: 1) for code that You delete from the Original Code; 2) +separate from the Original Code; or 3) for infringements caused by: i) +the modification of the Original Code or ii) the combination of the +Original Code with other software or devices. + +2.2. Contributor Grant. Subject to third party intellectual property +claims, each Contributor hereby grants You a world-wide, royalty-free, +non-exclusive license + +(a) under intellectual property rights (other than patent or +trademark) Licensable by Contributor, to use, reproduce, modify, +display, perform, sublicense and distribute the Modifications created +by such Contributor (or portions thereof) either on an unmodified +basis, with other Modifications, as Covered Code and/or as part of a +Larger Work; and + +(b) under Patent Claims infringed by the making, using, or selling of +Modifications made by that Contributor either alone and/or in +combination with its Contributor Version (or portions of such +combination), to make, use, sell, offer for sale, have made, and/or +otherwise dispose of: 1) Modifications made by that Contributor (or +portions thereof); and 2) the combination of Modifications made by +that Contributor with its Contributor Version (or portions of such +combination). + +(c) the licenses granted in Sections 2.2(a) and 2.2(b) are effective +on the date Contributor first makes Commercial Use of the Covered +Code. + +(d) Notwithstanding Section 2.2(b) above, no patent license is +granted: 1) for any code that Contributor has deleted from the +Contributor Version; 2) separate from the Contributor Version; 3) for +infringements caused by: i) third party modifications of Contributor +Version or ii) the combination of Modifications made by that +Contributor with other software (except as part of the Contributor +Version) or other devices; or 4) under Patent Claims infringed by +Covered Code in the absence of Modifications made by that Contributor. + + +3. Distribution Obligations. + +3.1. Application of License. The Modifications which You create or to +which You contribute are governed by the terms of this License, +including without limitation Section 2.2. The Source Code version of +Covered Code may be distributed only under the terms of this License +or a future version of this License released under Section 6.1, and +You must include a copy of this License with every copy of the Source +Code You distribute. You may not offer or impose any terms on any +Source Code version that alters or restricts the applicable version of +this License or the recipients' rights hereunder. However, You may +include an additional document offering the additional rights +described in Section 3.5. + +3.2. Availability of Source Code. Any Modification which You create +or to which You contribute must be made available in Source Code form +under the terms of this License either on the same media as an +Executable version or via an accepted Electronic Distribution +Mechanism to anyone to whom you made an Executable version available; +and if made available via Electronic Distribution Mechanism, must +remain available for at least twelve (12) months after the date it +initially became available, or at least six (6) months after a +subsequent version of that particular Modification has been made +available to such recipients. You are responsible for ensuring that +the Source Code version remains available even if the Electronic +Distribution Mechanism is maintained by a third party. + +3.3. Description of Modifications. You must cause all Covered Code to +which You contribute to contain a file documenting the changes You +made to create that Covered Code and the date of any change. You must +include a prominent statement that the Modification is derived, +directly or indirectly, from Original Code provided by the Initial +Developer and including the name of the Initial Developer in (a) the +Source Code, and (b) in any notice in an Executable version or related +documentation in which You describe the origin or ownership of the +Covered Code. + +3.4. Intellectual Property Matters (a) Third Party Claims. If +Contributor has knowledge that a license under a third party's +intellectual property rights is required to exercise the rights +granted by such Contributor under Sections 2.1 or 2.2, Contributor +must include a text file with the Source Code distribution titled +"LEGAL" which describes the claim and the party making the claim in +sufficient detail that a recipient will know whom to contact. If +Contributor obtains such knowledge after the Modification is made +available as described in Section 3.2, Contributor shall promptly +modify the LEGAL file in all copies Contributor makes available +thereafter and shall take other steps (such as notifying appropriate +mailing lists or newsgroups) reasonably calculated to inform those who +received the Covered Code that new knowledge has been obtained. + +(b) Contributor APIs. If Contributor's Modifications include an +application programming interface and Contributor has knowledge of +patent licenses which are reasonably necessary to implement that API, +Contributor must also include this information in the LEGAL file. + +(c) Representations. Contributor represents that, except as disclosed +pursuant to Section 3.4(a) above, Contributor believes that +Contributor's Modifications are Contributor's original creation(s) +and/or Contributor has sufficient rights to grant the rights conveyed +by this License. + + +3.5. Required Notices. You must duplicate the notice in Exhibit A in +each file of the Source Code. If it is not possible to put such +notice in a particular Source Code file due to its structure, then You +must include such notice in a location (such as a relevant directory) +where a user would be likely to look for such a notice. If You +created one or more Modification(s) You may add your name as a +Contributor to the notice described in Exhibit A. You must also +duplicate this License in any documentation for the Source Code where +You describe recipients' rights or ownership rights relating to +Covered Code. You may choose to offer, and to charge a fee for, +warranty, support, indemnity or liability obligations to one or more +recipients of Covered Code. However, You may do so only on Your own +behalf, and not on behalf of the Initial Developer or any +Contributor. You must make it absolutely clear than any such warranty, +support, indemnity or liability obligation is offered by You alone, +and You hereby agree to indemnify the Initial Developer and every +Contributor for any liability incurred by the Initial Developer or +such Contributor as a result of warranty, support, indemnity or +liability terms You offer. + +3.6. Distribution of Executable Versions. You may distribute Covered +Code in Executable form only if the requirements of Section 3.1-3.5 +have been met for that Covered Code, and if You include a notice +stating that the Source Code version of the Covered Code is available +under the terms of this License, including a description of how and +where You have fulfilled the obligations of Section 3.2. The notice +must be conspicuously included in any notice in an Executable version, +related documentation or collateral in which You describe recipients' +rights relating to the Covered Code. You may distribute the Executable +version of Covered Code or ownership rights under a license of Your +choice, which may contain terms different from this License, provided +that You are in compliance with the terms of this License and that the +license for the Executable version does not attempt to limit or alter +the recipient's rights in the Source Code version from the rights set +forth in this License. If You distribute the Executable version under +a different license You must make it absolutely clear that any terms +which differ from this License are offered by You alone, not by the +Initial Developer or any Contributor. You hereby agree to indemnify +the Initial Developer and every Contributor for any liability incurred +by the Initial Developer or such Contributor as a result of any such +terms You offer. + +3.7. Larger Works. You may create a Larger Work by combining Covered +Code with other code not governed by the terms of this License and +distribute the Larger Work as a single product. In such a case, You +must make sure the requirements of this License are fulfilled for the +Covered Code. + +4. Inability to Comply Due to Statute or Regulation. + +If it is impossible for You to comply with any of the terms of this +License with respect to some or all of the Covered Code due to +statute, judicial order, or regulation then You must: (a) comply with +the terms of this License to the maximum extent possible; and (b) +describe the limitations and the code they affect. Such description +must be included in the LEGAL file described in Section 3.4 and must +be included with all distributions of the Source Code. Except to the +extent prohibited by statute or regulation, such description must be +sufficiently detailed for a recipient of ordinary skill to be able to +understand it. + +5. Application of this License. + +This License applies to code to which the Initial Developer has +attached the notice in Exhibit A and to related Covered Code. + +6. Versions of the License. + +6.1. New Versions. Thomas Richter may publish revised and/or new +versions of the License from time to time. Each version will be given +a distinguishing version number. + +6.2. Effect of New Versions. Once Covered Code has been published +under a particular version of the License, You may always continue to +use it under the terms of that version. You may also choose to use +such Covered Code under the terms of any subsequent version of the +License published by Thomas Richter. No one other than Thomas Richter +has the right to modify the terms applicable to Covered Code created +under this License. + +6.3. Derivative Works. If You create or use a modified version of +this License (which you may only do in order to apply it to code which +is not already Covered Code governed by this License), You must (a) +rename Your license so that the phrases "TPL", "THOR Software", +"Thomas Richter" or any confusingly similar phrase do not appear in +your license (except to note that your license differs from this +License) and (b) otherwise make it clear that Your version of the +license contains terms which differ from the THOR Public +License. (Filling in the name of the Initial Developer, Original Code +or Contributor in the notice described in Exhibit A shall not of +themselves be deemed to be modifications of this License.) + +7. DISCLAIMER OF WARRANTY. + +COVERED CODE IS PROVIDED UNDER THIS LICENSE ON AN "AS IS" BASIS, +WITHOUT WARRANTY OF ANY KIND, EITHER EXPRESSED OR IMPLIED, INCLUDING, +WITHOUT LIMITATION, WARRANTIES THAT THE COVERED CODE IS FREE OF +DEFECTS, MERCHANTABLE, FIT FOR A PARTICULAR PURPOSE OR +NON-INFRINGING. THE ENTIRE RISK AS TO THE QUALITY AND PERFORMANCE OF +THE COVERED CODE IS WITH YOU. SHOULD ANY COVERED CODE PROVE DEFECTIVE +IN ANY RESPECT, YOU (NOT THE INITIAL DEVELOPER OR ANY OTHER +CONTRIBUTOR) ASSUME THE COST OF ANY NECESSARY SERVICING, REPAIR OR +CORRECTION. THIS DISCLAIMER OF WARRANTY CONSTITUTES AN ESSENTIAL PART +OF THIS LICENSE. NO USE OF ANY COVERED CODE IS AUTHORIZED HEREUNDER +EXCEPT UNDER THIS DISCLAIMER. + +8. TERMINATION. + +8.1. This License and the rights granted hereunder will terminate +automatically if You fail to comply with terms herein and fail to cure +such breach within 30 days of becoming aware of the breach. All +sublicenses to the Covered Code which are properly granted shall +survive any termination of this License. Provisions which, by their +nature, must remain in effect beyond the termination of this License +shall survive. + +8.2. If You initiate litigation by asserting a patent infringement +claim (excluding declatory judgment actions) against Initial Developer +or a Contributor (the Initial Developer or Contributor against whom +You file such action is referred to as "Participant") alleging that: + +(a) such Participant's Contributor Version directly or indirectly +infringes any patent, then any and all rights granted by such +Participant to You under Sections 2.1 and/or 2.2 of this License +shall, upon 60 days notice from Participant terminate prospectively, +unless if within 60 days after receipt of notice You either: (i) agree +in writing to pay Participant a mutually agreeable reasonable royalty +for Your past and future use of Modifications made by such +Participant, or (ii) withdraw Your litigation claim with respect to +the Contributor Version against such Participant. If within 60 days +of notice, a reasonable royalty and payment arrangement are not +mutually agreed upon in writing by the parties or the litigation claim +is not withdrawn, the rights granted by Participant to You under +Sections 2.1 and/or 2.2 automatically terminate at the expiration of +the 60 day notice period specified above. + +(b) any software, hardware, or device, other than such Participant's +Contributor Version, directly or indirectly infringes any patent, then +any rights granted to You by such Participant under Sections 2.1(b) +and 2.2(b) are revoked effective as of the date You first made, used, +sold, distributed, or had made, Modifications made by that +Participant. + +8.3. If You assert a patent infringement claim against Participant +alleging that such Participant's Contributor Version directly or +indirectly infringes any patent where such claim is resolved (such as +by license or settlement) prior to the initiation of patent +infringement litigation, then the reasonable value of the licenses +granted by such Participant under Sections 2.1 or 2.2 shall be taken +into account in determining the amount or value of any payment or +license. + +8.4. In the event of termination under Sections 8.1 or 8.2 above, all +end user license agreements (excluding distributors and resellers) +which have been validly granted by You or any distributor hereunder +prior to termination shall survive termination. + +9. LIMITATION OF LIABILITY. + +UNDER NO CIRCUMSTANCES AND UNDER NO LEGAL THEORY, WHETHER TORT +(INCLUDING NEGLIGENCE), CONTRACT, OR OTHERWISE, SHALL YOU, THE INITIAL +DEVELOPER, ANY OTHER CONTRIBUTOR, OR ANY DISTRIBUTOR OF COVERED CODE, +OR ANY SUPPLIER OF ANY OF SUCH PARTIES, BE LIABLE TO ANY PERSON FOR +ANY INDIRECT, SPECIAL, INCIDENTAL, OR CONSEQUENTIAL DAMAGES OF ANY +CHARACTER INCLUDING, WITHOUT LIMITATION, DAMAGES FOR LOSS OF GOODWILL, +WORK STOPPAGE, COMPUTER FAILURE OR MALFUNCTION, OR ANY AND ALL OTHER +COMMERCIAL DAMAGES OR LOSSES, EVEN IF SUCH PARTY SHALL HAVE BEEN +INFORMED OF THE POSSIBILITY OF SUCH DAMAGES. THIS LIMITATION OF +LIABILITY SHALL NOT APPLY TO LIABILITY FOR DEATH OR PERSONAL INJURY +RESULTING FROM SUCH PARTY'S NEGLIGENCE TO THE EXTENT APPLICABLE LAW +PROHIBITS SUCH LIMITATION. SOME JURISDICTIONS DO NOT ALLOW THE +EXCLUSION OR LIMITATION OF INCIDENTAL OR CONSEQUENTIAL DAMAGES, SO +THIS EXCLUSION AND LIMITATION MAY NOT APPLY TO YOU. + +10. U.S. GOVERNMENT END USERS. + +The Covered Code is a "commercial item," as that term is defined in 48 +C.F.R. 2.101 (Oct. 1995), consisting of "commercial computer software" +and "commercial computer software documentation," as such terms are +used in 48 C.F.R. 12.212 (Sept. 1995). Consistent with 48 +C.F.R. 12.212 and 48 C.F.R. 227.7202-1 through 227.7202-4 (June 1995), +all U.S. Government End Users acquire Covered Code with only those +rights set forth herein. + +11. MISCELLANEOUS. + +This License represents the complete agreement concerning subject +matter hereof. If any provision of this License is held to be +unenforceable, such provision shall be reformed only to the extent +necessary to make it enforceable. This License shall be governed by +German law provisions (except to the extent applicable law, if any, +provides otherwise), excluding its conflict-of-law provisions. With +respect to disputes in which at least one party is a citizen of, or an +entity chartered or registered to do business in Federal Republic of +Germany, any litigation relating to this License shall be subject to +the jurisdiction of the Federal Courts of the Federal Republic of +Germany, with the losing party responsible for costs, including +without limitation, court costs and reasonable attorneys' fees and +expenses. Any law or regulation which provides that the language of a +contract shall be construed against the drafter shall not apply to +this License. + +12. RESPONSIBILITY FOR CLAIMS. + +As between Initial Developer and the Contributors, each party is +responsible for claims and damages arising, directly or indirectly, +out of its utilization of rights under this License and You agree to +work with Initial Developer and Contributors to distribute such +responsibility on an equitable basis. Nothing herein is intended or +shall be deemed to constitute any admission of liability. + +13. MULTIPLE-LICENSED CODE. + +Initial Developer may designate portions of the Covered Code as +Multiple-Licensed. Multiple-Licensed means that the Initial Developer +permits you to utilize portions of the Covered Code under Your choice +of the TPL or the alternative licenses, if any, specified by the +Initial Developer in the file described in Exhibit A. + + +EXHIBIT A - THOR Public License. + +The contents of this file are subject to the THOR Public License +Version 1.0 (the "License"); you may not use this file except in +compliance with the License. + +Software distributed under the License is distributed on an "AS IS" +basis, WITHOUT WARRANTY OF ANY KIND, either express or implied. See +the License for the specificlanguage governing rights and limitations +under the License. + +The Original Code is ______________________________________. + +The Initial Developer of the Original Code is _____________. + +Portions created by ______________________ are +Copyright (C) ______ _______________________. + +All Rights Reserved. + +Contributor(s): ______________________________________. + +Alternatively, the contents of this file may be used under the terms +of the _____ license (the [___] License), in which case the provisions +of [______] License are applicable instead of those above. If you +wish to allow use of your version of this file only under the terms of +the [____] License and not to allow others to use your version of this +file under the TPL, indicate your decision by deleting the provisions +above and replace them with the notice and other provisions required +by the [___] License. If you do not delete the provisions above, a +recipient may use your version of this file under either the TPL or +the [___] License." + +[NOTE: The text of this Exhibit A may differ slightly from the text of +the notices in the Source Code files of the Original Code. You should +use the text of this Exhibit A rather than the text found in the +Original Code Source Code for Your Modifications.] diff --git a/options/license/UCAR b/options/license/UCAR new file mode 100644 index 0000000000000..36e1810283ee7 --- /dev/null +++ b/options/license/UCAR @@ -0,0 +1,32 @@ +Copyright 2014 University Corporation for Atmospheric Research and contributors. +All rights reserved. + +This software was developed by the Unidata Program Center of the +University Corporation for Atmospheric Research (UCAR) +. + +Redistribution and use in source and binary forms, with or without modification, +are permitted provided that the following conditions are met: + + 1) Redistributions of source code must retain the above copyright notice, + this list of conditions and the following disclaimer. + 2) Redistributions in binary form must reproduce the above copyright notice, + this list of conditions and the following disclaimer in the documentation + and/or other materials provided with the distribution. + 3) Neither the names of the development group, the copyright holders, nor the + names of contributors may be used to endorse or promote products derived + from this software without specific prior written permission. + 4) This license shall terminate automatically and you may no longer exercise + any of the rights granted to you by this license as of the date you + commence an action, including a cross-claim or counterclaim, against + the copyright holders or any contributor alleging that this software + infringes a patent. This termination provision shall not apply for an + action alleging patent infringement by combinations of this software with + other software or hardware. + +THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR +IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY, FITNESS +FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE CONTRIBUTORS +OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER LIABILITY, +WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM, OUT OF OR IN +CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS WITH THE SOFTWARE. diff --git a/options/license/snprintf b/options/license/snprintf new file mode 100644 index 0000000000000..9e4ae73daaea8 --- /dev/null +++ b/options/license/snprintf @@ -0,0 +1,3 @@ +Copyright Patrick Powell 1995 + +This code is based on code written by Patrick Powell (papowell@astart.com) It may be used for any purpose as long as this notice remains intact on all source code distributions diff --git a/options/license/w3m b/options/license/w3m new file mode 100644 index 0000000000000..37081007bf3f0 --- /dev/null +++ b/options/license/w3m @@ -0,0 +1,11 @@ +(C) Copyright 1994-2002 by Akinori Ito +(C) Copyright 2002-2011 by Akinori Ito, Hironori Sakamoto, Fumitoshi Ukai + +Use, modification and redistribution of this software is hereby granted, +provided that this entire copyright notice is included on any copies of +this software and applications and derivations thereof. + +This software is provided on an "as is" basis, without warranty of any +kind, either expressed or implied, as to any matter including, but not +limited to warranty of fitness of purpose, or merchantability, or +results obtained from use of this software. diff --git a/options/license/xlock b/options/license/xlock new file mode 100644 index 0000000000000..39ccda0b4d4ce --- /dev/null +++ b/options/license/xlock @@ -0,0 +1,14 @@ +Copyright (c) 1990 by Sun Microsystems, Inc. +Author: Patrick J. Naughton naughton@wind.sun.com + +Permission to use, copy, modify, and distribute this software and its +documentation for any purpose and without fee is hereby granted, +provided that the above copyright notice appear in all copies and +that both that copyright notice and this permission notice appear in +supporting documentation. + +This file is provided AS IS with no warranties of any kind. The author +shall have no liability with respect to the infringement of copyrights, +trade secrets or any patents by this file or any part thereof. In no event +will the author be liable for any lost revenue or profits or other special, +indirect and consequential damages.