You are viewing a plain text version of this content. The canonical link for it is here.
Posted to notifications@skywalking.apache.org by li...@apache.org on 2020/12/08 14:07:17 UTC

[skywalking-satellite] 01/01: delete-plugin-framework-examples

This is an automated email from the ASF dual-hosted git repository.

liujiapeng pushed a commit to branch delete-plugin-framework-examples
in repository https://gitbox.apache.org/repos/asf/skywalking-satellite.git

commit d4b47cc56ee4cf9bb000145d142ecbe8f54be636
Author: Evan <ev...@outlook.com>
AuthorDate: Tue Dec 8 22:04:41 2020 +0800

    delete-plugin-framework-examples
---
 plugins/client/example/client.go              | 67 -------------------------
 plugins/client/example/client_test.go         | 71 --------------------------
 plugins/collector/example/collector.go        | 70 --------------------------
 plugins/collector/example/collector_test.go   | 71 --------------------------
 plugins/fallbacker/example/fallbacker.go      | 57 ---------------------
 plugins/fallbacker/example/fallbacker_test.go | 71 --------------------------
 plugins/filter/example/filter.go              | 54 --------------------
 plugins/filter/example/filter_test.go         | 71 --------------------------
 plugins/forwarder/example/forwarder.go        | 62 -----------------------
 plugins/forwarder/example/forwarder_test.go   | 71 --------------------------
 plugins/parser/example/parser.go              | 62 -----------------------
 plugins/parser/example/parser_test.go         | 71 --------------------------
 plugins/queue/example/queue.go                | 72 ---------------------------
 plugins/queue/example/queue_test.go           | 71 --------------------------
 14 files changed, 941 deletions(-)

diff --git a/plugins/client/example/client.go b/plugins/client/example/client.go
deleted file mode 100644
index 77b29c7..0000000
--- a/plugins/client/example/client.go
+++ /dev/null
@@ -1,67 +0,0 @@
-// Licensed to Apache Software Foundation (ASF) under one or more contributor
-// license agreements. See the NOTICE file distributed with
-// this work for additional information regarding copyright
-// ownership. Apache Software Foundation (ASF) licenses this file to you under
-// the Apache License, Version 2.0 (the "License"); you may
-// not use this file except in compliance with the License.
-// You may obtain a copy of the License at
-//
-//     http://www.apache.org/licenses/LICENSE-2.0
-//
-// Unless required by applicable law or agreed to in writing,
-// software distributed under the License is distributed on an
-// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-// KIND, either express or implied.  See the License for the
-// specific language governing permissions and limitations
-// under the License.
-
-package example
-
-type demoClient struct {
-	a string
-}
-type demoClient2 struct {
-	a string
-}
-type demoClient3 struct {
-	a string
-}
-
-func (d demoClient) Description() string {
-	panic("implement me")
-}
-
-func (d demoClient) InitPlugin(config map[string]interface{}) {
-
-}
-
-func (d demoClient) Prepare() {
-	panic("implement me")
-}
-
-func (d demoClient) GetConnectedClient() interface{} {
-	panic("implement me")
-}
-
-func (d demoClient) Close() {
-	panic("implement me")
-}
-
-func (d *demoClient2) Description() string {
-	panic("implement me")
-}
-
-func (d *demoClient2) InitPlugin(config map[string]interface{}) {
-}
-
-func (d *demoClient2) Prepare() {
-	panic("implement me")
-}
-
-func (d *demoClient2) GetConnectedClient() interface{} {
-	panic("implement me")
-}
-
-func (d *demoClient2) Close() {
-	panic("implement me")
-}
diff --git a/plugins/client/example/client_test.go b/plugins/client/example/client_test.go
deleted file mode 100644
index a9e355e..0000000
--- a/plugins/client/example/client_test.go
+++ /dev/null
@@ -1,71 +0,0 @@
-// Licensed to Apache Software Foundation (ASF) under one or more contributor
-// license agreements. See the NOTICE file distributed with
-// this work for additional information regarding copyright
-// ownership. Apache Software Foundation (ASF) licenses this file to you under
-// the Apache License, Version 2.0 (the "License"); you may
-// not use this file except in compliance with the License.
-// You may obtain a copy of the License at
-//
-//     http://www.apache.org/licenses/LICENSE-2.0
-//
-// Unless required by applicable law or agreed to in writing,
-// software distributed under the License is distributed on an
-// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-// KIND, either express or implied.  See the License for the
-// specific language governing permissions and limitations
-// under the License.
-
-package example
-
-import (
-	"testing"
-
-	"github.com/apache/skywalking-satellite/internal/pkg/plugin"
-	"github.com/apache/skywalking-satellite/plugins/client/api"
-)
-
-func Test_Register(t *testing.T) {
-	tests := []struct {
-		name  string
-		args  interface{}
-		panic bool
-	}{
-		{
-			name: "demoClient",
-			args: demoClient{
-				a: "s",
-			},
-			panic: false,
-		},
-		{
-			name: "demoClient2",
-			args: &demoClient2{
-				a: "s",
-			},
-			panic: false,
-		},
-		{
-			name: "demoClient3",
-			args: demoClient3{
-				a: "s",
-			},
-			panic: true,
-		},
-	}
-
-	for _, tt := range tests {
-		t.Run(tt.name, func(t *testing.T) {
-			plugin.RegisterPlugin(tt.name, tt.args)
-			assertPanic(t, tt.name, nil, tt.panic)
-		})
-	}
-}
-
-func assertPanic(t *testing.T, name string, config map[string]interface{}, existPanic bool) {
-	defer func() {
-		if r := recover(); r != nil && !existPanic {
-			t.Errorf("the plugin %s is not pass", name)
-		}
-	}()
-	api.GetClient(name, config)
-}
diff --git a/plugins/collector/example/collector.go b/plugins/collector/example/collector.go
deleted file mode 100644
index 40b9b8b..0000000
--- a/plugins/collector/example/collector.go
+++ /dev/null
@@ -1,70 +0,0 @@
-// Licensed to Apache Software Foundation (ASF) under one or more contributor
-// license agreements. See the NOTICE file distributed with
-// this work for additional information regarding copyright
-// ownership. Apache Software Foundation (ASF) licenses this file to you under
-// the Apache License, Version 2.0 (the "License"); you may
-// not use this file except in compliance with the License.
-// You may obtain a copy of the License at
-//
-//     http://www.apache.org/licenses/LICENSE-2.0
-//
-// Unless required by applicable law or agreed to in writing,
-// software distributed under the License is distributed on an
-// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-// KIND, either express or implied.  See the License for the
-// specific language governing permissions and limitations
-// under the License.
-
-package example
-
-import "github.com/apache/skywalking-satellite/internal/pkg/event"
-
-type demoCollector struct {
-	a string
-}
-
-type demoCollector2 struct {
-	a string
-}
-
-type demoCollector3 struct {
-	a string
-}
-
-func (d *demoCollector) Description() string {
-	panic("implement me")
-}
-
-func (d *demoCollector) InitPlugin(config map[string]interface{}) {
-}
-
-func (d *demoCollector) Prepare() {
-	panic("implement me")
-}
-
-func (d *demoCollector) Next() (event.SerializableEvent, error) {
-	panic("implement me")
-}
-
-func (d *demoCollector) Close() {
-	panic("implement me")
-}
-
-func (d demoCollector2) Description() string {
-	panic("implement me")
-}
-
-func (d demoCollector2) InitPlugin(config map[string]interface{}) {
-}
-
-func (d demoCollector2) Prepare() {
-	panic("implement me")
-}
-
-func (d demoCollector2) Next() (event.SerializableEvent, error) {
-	panic("implement me")
-}
-
-func (d demoCollector2) Close() {
-	panic("implement me")
-}
diff --git a/plugins/collector/example/collector_test.go b/plugins/collector/example/collector_test.go
deleted file mode 100644
index e73f3bd..0000000
--- a/plugins/collector/example/collector_test.go
+++ /dev/null
@@ -1,71 +0,0 @@
-// Licensed to Apache Software Foundation (ASF) under one or more contributor
-// license agreements. See the NOTICE file distributed with
-// this work for additional information regarding copyright
-// ownership. Apache Software Foundation (ASF) licenses this file to you under
-// the Apache License, Version 2.0 (the "License"); you may
-// not use this file except in compliance with the License.
-// You may obtain a copy of the License at
-//
-//     http://www.apache.org/licenses/LICENSE-2.0
-//
-// Unless required by applicable law or agreed to in writing,
-// software distributed under the License is distributed on an
-// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-// KIND, either express or implied.  See the License for the
-// specific language governing permissions and limitations
-// under the License.
-
-package example
-
-import (
-	"testing"
-
-	"github.com/apache/skywalking-satellite/internal/pkg/plugin"
-	"github.com/apache/skywalking-satellite/plugins/collector/api"
-)
-
-func Test_Register(t *testing.T) {
-	tests := []struct {
-		name  string
-		args  interface{}
-		panic bool
-	}{
-		{
-			name: "demoCollector",
-			args: &demoCollector{
-				a: "s",
-			},
-			panic: false,
-		},
-		{
-			name: "demoCollector2",
-			args: demoCollector2{
-				a: "s",
-			},
-			panic: false,
-		},
-		{
-			name: "demoCollector3",
-			args: demoCollector3{
-				a: "s",
-			},
-			panic: true,
-		},
-	}
-
-	for _, tt := range tests {
-		t.Run(tt.name, func(t *testing.T) {
-			plugin.RegisterPlugin(tt.name, tt.args)
-			assertPanic(t, tt.name, nil, tt.panic)
-		})
-	}
-}
-
-func assertPanic(t *testing.T, name string, config map[string]interface{}, existPanic bool) {
-	defer func() {
-		if r := recover(); r != nil && !existPanic {
-			t.Errorf("the plugin %s is not pass", name)
-		}
-	}()
-	api.GetCollector(name, config)
-}
diff --git a/plugins/fallbacker/example/fallbacker.go b/plugins/fallbacker/example/fallbacker.go
deleted file mode 100644
index b933e96..0000000
--- a/plugins/fallbacker/example/fallbacker.go
+++ /dev/null
@@ -1,57 +0,0 @@
-// Licensed to Apache Software Foundation (ASF) under one or more contributor
-// license agreements. See the NOTICE file distributed with
-// this work for additional information regarding copyright
-// ownership. Apache Software Foundation (ASF) licenses this file to you under
-// the Apache License, Version 2.0 (the "License"); you may
-// not use this file except in compliance with the License.
-// You may obtain a copy of the License at
-//
-//     http://www.apache.org/licenses/LICENSE-2.0
-//
-// Unless required by applicable law or agreed to in writing,
-// software distributed under the License is distributed on an
-// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-// KIND, either express or implied.  See the License for the
-// specific language governing permissions and limitations
-// under the License.
-
-package example
-
-import (
-	"github.com/apache/skywalking-satellite/internal/pkg/event"
-	"github.com/apache/skywalking-satellite/plugins/fallbacker/api"
-)
-
-type demoFallbacker struct {
-	a string
-}
-
-type demoFallbacker2 struct {
-	a string
-}
-
-type demoFallbacker3 struct {
-	a string
-}
-
-func (d *demoFallbacker) Description() string {
-	panic("implement me")
-}
-
-func (d *demoFallbacker) InitPlugin(config map[string]interface{}) {
-}
-
-func (d *demoFallbacker) FallBack(batch event.BatchEvents) api.Fallbacker {
-	panic("implement me")
-}
-
-func (d demoFallbacker2) Description() string {
-	panic("implement me")
-}
-
-func (d demoFallbacker2) InitPlugin(config map[string]interface{}) {
-}
-
-func (d demoFallbacker2) FallBack(batch event.BatchEvents) api.Fallbacker {
-	panic("implement me")
-}
diff --git a/plugins/fallbacker/example/fallbacker_test.go b/plugins/fallbacker/example/fallbacker_test.go
deleted file mode 100644
index f5f445f..0000000
--- a/plugins/fallbacker/example/fallbacker_test.go
+++ /dev/null
@@ -1,71 +0,0 @@
-// Licensed to Apache Software Foundation (ASF) under one or more contributor
-// license agreements. See the NOTICE file distributed with
-// this work for additional information regarding copyright
-// ownership. Apache Software Foundation (ASF) licenses this file to you under
-// the Apache License, Version 2.0 (the "License"); you may
-// not use this file except in compliance with the License.
-// You may obtain a copy of the License at
-//
-//     http://www.apache.org/licenses/LICENSE-2.0
-//
-// Unless required by applicable law or agreed to in writing,
-// software distributed under the License is distributed on an
-// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-// KIND, either express or implied.  See the License for the
-// specific language governing permissions and limitations
-// under the License.
-
-package example
-
-import (
-	"testing"
-
-	"github.com/apache/skywalking-satellite/internal/pkg/plugin"
-	"github.com/apache/skywalking-satellite/plugins/fallbacker/api"
-)
-
-func Test_Register(t *testing.T) {
-	tests := []struct {
-		name  string
-		args  interface{}
-		panic bool
-	}{
-		{
-			name: "demoFallbacker",
-			args: &demoFallbacker{
-				a: "s",
-			},
-			panic: false,
-		},
-		{
-			name: "demoFallbacker2",
-			args: demoFallbacker2{
-				a: "s",
-			},
-			panic: false,
-		},
-		{
-			name: "demoFallbacker3",
-			args: demoFallbacker3{
-				a: "s",
-			},
-			panic: true,
-		},
-	}
-
-	for _, tt := range tests {
-		t.Run(tt.name, func(t *testing.T) {
-			plugin.RegisterPlugin(tt.name, tt.args)
-			assertPanic(t, tt.name, nil, tt.panic)
-		})
-	}
-}
-
-func assertPanic(t *testing.T, name string, config map[string]interface{}, existPanic bool) {
-	defer func() {
-		if r := recover(); r != nil && !existPanic {
-			t.Errorf("the plugin %s is not pass", name)
-		}
-	}()
-	api.GetFallbacker(name, config)
-}
diff --git a/plugins/filter/example/filter.go b/plugins/filter/example/filter.go
deleted file mode 100644
index 14abb69..0000000
--- a/plugins/filter/example/filter.go
+++ /dev/null
@@ -1,54 +0,0 @@
-// Licensed to Apache Software Foundation (ASF) under one or more contributor
-// license agreements. See the NOTICE file distributed with
-// this work for additional information regarding copyright
-// ownership. Apache Software Foundation (ASF) licenses this file to you under
-// the Apache License, Version 2.0 (the "License"); you may
-// not use this file except in compliance with the License.
-// You may obtain a copy of the License at
-//
-//     http://www.apache.org/licenses/LICENSE-2.0
-//
-// Unless required by applicable law or agreed to in writing,
-// software distributed under the License is distributed on an
-// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-// KIND, either express or implied.  See the License for the
-// specific language governing permissions and limitations
-// under the License.
-
-package example
-
-import "github.com/apache/skywalking-satellite/internal/pkg/event"
-
-type demoFilter struct {
-	a string
-}
-
-type demoFilter2 struct {
-	a string
-}
-
-type demoFilter3 struct {
-	a string
-}
-
-func (d *demoFilter) Description() string {
-	panic("implement me")
-}
-
-func (d *demoFilter) InitPlugin(config map[string]interface{}) {
-}
-
-func (d *demoFilter) Process(in event.Event) event.Event {
-	panic("implement me")
-}
-
-func (d demoFilter2) Description() string {
-	panic("implement me")
-}
-
-func (d demoFilter2) InitPlugin(config map[string]interface{}) {
-}
-
-func (d demoFilter2) Process(in event.Event) event.Event {
-	panic("implement me")
-}
diff --git a/plugins/filter/example/filter_test.go b/plugins/filter/example/filter_test.go
deleted file mode 100644
index aae4371..0000000
--- a/plugins/filter/example/filter_test.go
+++ /dev/null
@@ -1,71 +0,0 @@
-// Licensed to Apache Software Foundation (ASF) under one or more contributor
-// license agreements. See the NOTICE file distributed with
-// this work for additional information regarding copyright
-// ownership. Apache Software Foundation (ASF) licenses this file to you under
-// the Apache License, Version 2.0 (the "License"); you may
-// not use this file except in compliance with the License.
-// You may obtain a copy of the License at
-//
-//     http://www.apache.org/licenses/LICENSE-2.0
-//
-// Unless required by applicable law or agreed to in writing,
-// software distributed under the License is distributed on an
-// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-// KIND, either express or implied.  See the License for the
-// specific language governing permissions and limitations
-// under the License.
-
-package example
-
-import (
-	"testing"
-
-	"github.com/apache/skywalking-satellite/internal/pkg/plugin"
-	"github.com/apache/skywalking-satellite/plugins/filter/api"
-)
-
-func Test_Register(t *testing.T) {
-	tests := []struct {
-		name  string
-		args  interface{}
-		panic bool
-	}{
-		{
-			name: "demoFilter",
-			args: &demoFilter{
-				a: "s",
-			},
-			panic: false,
-		},
-		{
-			name: "demoFilter2",
-			args: demoFilter2{
-				a: "s",
-			},
-			panic: false,
-		},
-		{
-			name: "demoFilter3",
-			args: demoFilter3{
-				a: "s",
-			},
-			panic: true,
-		},
-	}
-
-	for _, tt := range tests {
-		t.Run(tt.name, func(t *testing.T) {
-			plugin.RegisterPlugin(tt.name, tt.args)
-			assertPanic(t, tt.name, nil, tt.panic)
-		})
-	}
-}
-
-func assertPanic(t *testing.T, name string, config map[string]interface{}, existPanic bool) {
-	defer func() {
-		if r := recover(); r != nil && !existPanic {
-			t.Errorf("the plugin %s is not pass", name)
-		}
-	}()
-	api.GetFilter(name, config)
-}
diff --git a/plugins/forwarder/example/forwarder.go b/plugins/forwarder/example/forwarder.go
deleted file mode 100644
index 637f9e1..0000000
--- a/plugins/forwarder/example/forwarder.go
+++ /dev/null
@@ -1,62 +0,0 @@
-// Licensed to Apache Software Foundation (ASF) under one or more contributor
-// license agreements. See the NOTICE file distributed with
-// this work for additional information regarding copyright
-// ownership. Apache Software Foundation (ASF) licenses this file to you under
-// the Apache License, Version 2.0 (the "License"); you may
-// not use this file except in compliance with the License.
-// You may obtain a copy of the License at
-//
-//     http://www.apache.org/licenses/LICENSE-2.0
-//
-// Unless required by applicable law or agreed to in writing,
-// software distributed under the License is distributed on an
-// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-// KIND, either express or implied.  See the License for the
-// specific language governing permissions and limitations
-// under the License.
-
-package example
-
-import "github.com/apache/skywalking-satellite/internal/pkg/event"
-
-type demoForwarder struct {
-	a string
-}
-
-type demoForwarder2 struct {
-	a string
-}
-
-type demoForwarder3 struct {
-	a string
-}
-
-func (d *demoForwarder) Description() string {
-	panic("implement me")
-}
-
-func (d *demoForwarder) InitPlugin(config map[string]interface{}) {
-}
-
-func (d *demoForwarder) Forward(batch event.BatchEvents) {
-	panic("implement me")
-}
-
-func (d demoForwarder2) Description() string {
-	panic("implement me")
-}
-
-func (d demoForwarder2) InitPlugin(config map[string]interface{}) {
-}
-
-func (d demoForwarder2) Forward(batch event.BatchEvents) {
-	panic("implement me")
-}
-
-func (d demoForwarder2) ForwardType() event.Type {
-	panic("implement me")
-}
-
-func (d *demoForwarder) ForwardType() event.Type {
-	panic("implement me")
-}
diff --git a/plugins/forwarder/example/forwarder_test.go b/plugins/forwarder/example/forwarder_test.go
deleted file mode 100644
index 28de35d..0000000
--- a/plugins/forwarder/example/forwarder_test.go
+++ /dev/null
@@ -1,71 +0,0 @@
-// Licensed to Apache Software Foundation (ASF) under one or more contributor
-// license agreements. See the NOTICE file distributed with
-// this work for additional information regarding copyright
-// ownership. Apache Software Foundation (ASF) licenses this file to you under
-// the Apache License, Version 2.0 (the "License"); you may
-// not use this file except in compliance with the License.
-// You may obtain a copy of the License at
-//
-//     http://www.apache.org/licenses/LICENSE-2.0
-//
-// Unless required by applicable law or agreed to in writing,
-// software distributed under the License is distributed on an
-// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-// KIND, either express or implied.  See the License for the
-// specific language governing permissions and limitations
-// under the License.
-
-package example
-
-import (
-	"testing"
-
-	"github.com/apache/skywalking-satellite/internal/pkg/plugin"
-	"github.com/apache/skywalking-satellite/plugins/forwarder/api"
-)
-
-func Test_Register(t *testing.T) {
-	tests := []struct {
-		name  string
-		args  interface{}
-		panic bool
-	}{
-		{
-			name: "demoForwarder",
-			args: &demoForwarder{
-				a: "s",
-			},
-			panic: false,
-		},
-		{
-			name: "demoForwarder2",
-			args: demoForwarder2{
-				a: "s",
-			},
-			panic: false,
-		},
-		{
-			name: "demoForwarder3",
-			args: demoForwarder3{
-				a: "s",
-			},
-			panic: true,
-		},
-	}
-
-	for _, tt := range tests {
-		t.Run(tt.name, func(t *testing.T) {
-			plugin.RegisterPlugin(tt.name, tt.args)
-			assertPanic(t, tt.name, nil, tt.panic)
-		})
-	}
-}
-
-func assertPanic(t *testing.T, name string, config map[string]interface{}, existPanic bool) {
-	defer func() {
-		if r := recover(); r != nil && !existPanic {
-			t.Errorf("the plugin %s is not pass", name)
-		}
-	}()
-	api.GetForwarder(name, config)
-}
diff --git a/plugins/parser/example/parser.go b/plugins/parser/example/parser.go
deleted file mode 100644
index 839956f..0000000
--- a/plugins/parser/example/parser.go
+++ /dev/null
@@ -1,62 +0,0 @@
-// Licensed to Apache Software Foundation (ASF) under one or more contributor
-// license agreements. See the NOTICE file distributed with
-// this work for additional information regarding copyright
-// ownership. Apache Software Foundation (ASF) licenses this file to you under
-// the Apache License, Version 2.0 (the "License"); you may
-// not use this file except in compliance with the License.
-// You may obtain a copy of the License at
-//
-//     http://www.apache.org/licenses/LICENSE-2.0
-//
-// Unless required by applicable law or agreed to in writing,
-// software distributed under the License is distributed on an
-// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-// KIND, either express or implied.  See the License for the
-// specific language governing permissions and limitations
-// under the License.
-
-package example
-
-import "github.com/apache/skywalking-satellite/internal/pkg/event"
-
-type demoParser struct {
-	a string
-}
-
-type demoParser2 struct {
-	a string
-}
-
-type demoParser3 struct {
-	a string
-}
-
-func (d *demoParser) Description() string {
-	panic("implement me")
-}
-
-func (d *demoParser) InitPlugin(config map[string]interface{}) {
-}
-
-func (d *demoParser) ParseBytes(bytes []byte) ([]event.SerializableEvent, error) {
-	panic("implement me")
-}
-
-func (d *demoParser) ParseStr(str string) ([]event.SerializableEvent, error) {
-	panic("implement me")
-}
-
-func (d demoParser2) Description() string {
-	panic("implement me")
-}
-
-func (d demoParser2) InitPlugin(config map[string]interface{}) {
-}
-
-func (d demoParser2) ParseBytes(bytes []byte) ([]event.SerializableEvent, error) {
-	panic("implement me")
-}
-
-func (d demoParser2) ParseStr(str string) ([]event.SerializableEvent, error) {
-	panic("implement me")
-}
diff --git a/plugins/parser/example/parser_test.go b/plugins/parser/example/parser_test.go
deleted file mode 100644
index b577f7d..0000000
--- a/plugins/parser/example/parser_test.go
+++ /dev/null
@@ -1,71 +0,0 @@
-// Licensed to Apache Software Foundation (ASF) under one or more contributor
-// license agreements. See the NOTICE file distributed with
-// this work for additional information regarding copyright
-// ownership. Apache Software Foundation (ASF) licenses this file to you under
-// the Apache License, Version 2.0 (the "License"); you may
-// not use this file except in compliance with the License.
-// You may obtain a copy of the License at
-//
-//     http://www.apache.org/licenses/LICENSE-2.0
-//
-// Unless required by applicable law or agreed to in writing,
-// software distributed under the License is distributed on an
-// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-// KIND, either express or implied.  See the License for the
-// specific language governing permissions and limitations
-// under the License.
-
-package example
-
-import (
-	"testing"
-
-	"github.com/apache/skywalking-satellite/internal/pkg/plugin"
-	"github.com/apache/skywalking-satellite/plugins/parser/api"
-)
-
-func Test_Register(t *testing.T) {
-	tests := []struct {
-		name  string
-		args  interface{}
-		panic bool
-	}{
-		{
-			name: "demoParser",
-			args: &demoParser{
-				a: "s",
-			},
-			panic: false,
-		},
-		{
-			name: "demoParser2",
-			args: demoParser2{
-				a: "s",
-			},
-			panic: false,
-		},
-		{
-			name: "demoParser3",
-			args: demoParser3{
-				a: "s",
-			},
-			panic: true,
-		},
-	}
-
-	for _, tt := range tests {
-		t.Run(tt.name, func(t *testing.T) {
-			plugin.RegisterPlugin(tt.name, tt.args)
-			assertPanic(t, tt.name, nil, tt.panic)
-		})
-	}
-}
-
-func assertPanic(t *testing.T, name string, config map[string]interface{}, existPanic bool) {
-	defer func() {
-		if r := recover(); r != nil && !existPanic {
-			t.Errorf("the plugin %s is not pass", name)
-		}
-	}()
-	api.GetParser(name, config)
-}
diff --git a/plugins/queue/example/queue.go b/plugins/queue/example/queue.go
deleted file mode 100644
index 5a3055a..0000000
--- a/plugins/queue/example/queue.go
+++ /dev/null
@@ -1,72 +0,0 @@
-// Licensed to Apache Software Foundation (ASF) under one or more contributor
-// license agreements. See the NOTICE file distributed with
-// this work for additional information regarding copyright
-// ownership. Apache Software Foundation (ASF) licenses this file to you under
-// the Apache License, Version 2.0 (the "License"); you may
-// not use this file except in compliance with the License.
-// You may obtain a copy of the License at
-//
-//     http://www.apache.org/licenses/LICENSE-2.0
-//
-// Unless required by applicable law or agreed to in writing,
-// software distributed under the License is distributed on an
-// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-// KIND, either express or implied.  See the License for the
-// specific language governing permissions and limitations
-// under the License.
-
-package example
-
-import (
-	"github.com/apache/skywalking-satellite/plugins/queue/api"
-)
-
-type demoQueue struct {
-	a string
-}
-
-type demoQueue2 struct {
-	a string
-}
-
-type demoQueue3 struct {
-	a string
-}
-
-func (d *demoQueue) Description() string {
-	panic("implement me")
-}
-
-func (d *demoQueue) InitPlugin(config map[string]interface{}) {
-}
-
-func (d *demoQueue) Publisher() api.QueuePublisher {
-	panic("implement me")
-}
-
-func (d *demoQueue) Consumer() api.QueueConsumer {
-	panic("implement me")
-}
-
-func (d *demoQueue) Close() {
-	panic("implement me")
-}
-
-func (d demoQueue2) Description() string {
-	panic("implement me")
-}
-
-func (d demoQueue2) InitPlugin(config map[string]interface{}) {
-}
-
-func (d demoQueue2) Publisher() api.QueuePublisher {
-	panic("implement me")
-}
-
-func (d demoQueue2) Consumer() api.QueueConsumer {
-	panic("implement me")
-}
-
-func (d demoQueue2) Close() {
-	panic("implement me")
-}
diff --git a/plugins/queue/example/queue_test.go b/plugins/queue/example/queue_test.go
deleted file mode 100644
index 0afd20d..0000000
--- a/plugins/queue/example/queue_test.go
+++ /dev/null
@@ -1,71 +0,0 @@
-// Licensed to Apache Software Foundation (ASF) under one or more contributor
-// license agreements. See the NOTICE file distributed with
-// this work for additional information regarding copyright
-// ownership. Apache Software Foundation (ASF) licenses this file to you under
-// the Apache License, Version 2.0 (the "License"); you may
-// not use this file except in compliance with the License.
-// You may obtain a copy of the License at
-//
-//     http://www.apache.org/licenses/LICENSE-2.0
-//
-// Unless required by applicable law or agreed to in writing,
-// software distributed under the License is distributed on an
-// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-// KIND, either express or implied.  See the License for the
-// specific language governing permissions and limitations
-// under the License.
-
-package example
-
-import (
-	"testing"
-
-	"github.com/apache/skywalking-satellite/internal/pkg/plugin"
-	"github.com/apache/skywalking-satellite/plugins/queue/api"
-)
-
-func Test_Register(t *testing.T) {
-	tests := []struct {
-		name  string
-		args  interface{}
-		panic bool
-	}{
-		{
-			name: "demoQueue",
-			args: &demoQueue{
-				a: "s",
-			},
-			panic: false,
-		},
-		{
-			name: "demoQueue2",
-			args: demoQueue2{
-				a: "s",
-			},
-			panic: false,
-		},
-		{
-			name: "demoQueue3",
-			args: demoQueue3{
-				a: "s",
-			},
-			panic: true,
-		},
-	}
-
-	for _, tt := range tests {
-		t.Run(tt.name, func(t *testing.T) {
-			plugin.RegisterPlugin(tt.name, tt.args)
-			assertPanic(t, tt.name, nil, tt.panic)
-		})
-	}
-}
-
-func assertPanic(t *testing.T, name string, config map[string]interface{}, existPanic bool) {
-	defer func() {
-		if r := recover(); r != nil && !existPanic {
-			t.Errorf("the plugin %s is not pass", name)
-		}
-	}()
-	api.GetQueue(name, config)
-}