You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@celix.apache.org by pn...@apache.org on 2018/05/27 18:52:19 UTC

[11/60] [abbrv] [partial] celix git commit: CELIX-424: Cleans up the directory structure. Moves all libraries to the libs subdir and all bundles to the bundles subdir

http://git-wip-us.apache.org/repos/asf/celix/blob/3bce889b/framework/include/listener_hook_service.h
----------------------------------------------------------------------
diff --git a/framework/include/listener_hook_service.h b/framework/include/listener_hook_service.h
deleted file mode 100644
index d80c09e..0000000
--- a/framework/include/listener_hook_service.h
+++ /dev/null
@@ -1,59 +0,0 @@
-/*
- *Licensed to the 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.  The 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.
- */
-/*
- * listener_hook_service.h
- *
- *  \date       Oct 28, 2011
- *  \author    	<a href="mailto:dev@celix.apache.org">Apache Celix Project Team</a>
- *  \copyright	Apache License, Version 2.0
- */
-
-#ifndef LISTENER_HOOK_SERVICE_H_
-#define LISTENER_HOOK_SERVICE_H_
-
-
-typedef struct listener_hook_info *listener_hook_info_pt;
-typedef struct listener_hook_service *listener_hook_service_pt;
-
-#include "bundle_context.h"
-
-#define OSGI_FRAMEWORK_LISTENER_HOOK_SERVICE_NAME "listener_hook_service"
-#ifdef __cplusplus
-extern "C" {
-#endif
-
-struct listener_hook_info {
-	bundle_context_pt context;
-	const char *filter;
-	bool removed;
-};
-
-struct listener_hook_service {
-	void *handle;
-
-	celix_status_t (*added)(void *hook, array_list_pt listeners);
-
-	celix_status_t (*removed)(void *hook, array_list_pt listeners);
-};
-
-#ifdef __cplusplus
-}
-#endif
-
-#endif /* LISTENER_HOOK_SERVICE_H_ */

http://git-wip-us.apache.org/repos/asf/celix/blob/3bce889b/framework/include/manifest.h
----------------------------------------------------------------------
diff --git a/framework/include/manifest.h b/framework/include/manifest.h
deleted file mode 100644
index eeccfbc..0000000
--- a/framework/include/manifest.h
+++ /dev/null
@@ -1,67 +0,0 @@
-/**
- *Licensed to the 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.  The 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.
- */
-/*
- * manifest.h
- *
- *  \date       Jul 5, 2010
- *  \author    	<a href="mailto:dev@celix.apache.org">Apache Celix Project Team</a>
- *  \copyright	Apache License, Version 2.0
- */
-
-#ifndef MANIFEST_H_
-#define MANIFEST_H_
-
-#include "properties.h"
-#include "celix_errno.h"
-#include "framework_exports.h"
-
-#ifdef __cplusplus
-extern "C" {
-#endif
-
-struct manifest {
-	properties_pt mainAttributes;
-	hash_map_pt attributes;
-};
-
-typedef struct manifest *manifest_pt;
-
-FRAMEWORK_EXPORT celix_status_t manifest_create(manifest_pt *manifest);
-
-FRAMEWORK_EXPORT celix_status_t manifest_createFromFile(const char *filename, manifest_pt *manifest);
-
-FRAMEWORK_EXPORT celix_status_t manifest_destroy(manifest_pt manifest);
-
-FRAMEWORK_EXPORT void manifest_clear(manifest_pt manifest);
-
-FRAMEWORK_EXPORT properties_pt manifest_getMainAttributes(manifest_pt manifest);
-
-FRAMEWORK_EXPORT celix_status_t manifest_getEntries(manifest_pt manifest, hash_map_pt *map);
-
-FRAMEWORK_EXPORT celix_status_t manifest_read(manifest_pt manifest, const char *filename);
-
-FRAMEWORK_EXPORT void manifest_write(manifest_pt manifest, const char *filename);
-
-FRAMEWORK_EXPORT const char *manifest_getValue(manifest_pt manifest, const char *name);
-
-#ifdef __cplusplus
-}
-#endif
-
-#endif /* MANIFEST_H_ */

http://git-wip-us.apache.org/repos/asf/celix/blob/3bce889b/framework/include/module.h
----------------------------------------------------------------------
diff --git a/framework/include/module.h b/framework/include/module.h
deleted file mode 100644
index bc85ef4..0000000
--- a/framework/include/module.h
+++ /dev/null
@@ -1,94 +0,0 @@
-/**
- *Licensed to the 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.  The 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.
- */
-/*
- * module.h
- *
- *  \date       Jul 12, 2010
- *  \author    	<a href="mailto:dev@celix.apache.org">Apache Celix Project Team</a>
- *  \copyright	Apache License, Version 2.0
- */
-
-#ifndef MODULE_H_
-#define MODULE_H_
-
-typedef struct module *module_pt;
-
-#include "celixbool.h"
-#include "linked_list.h"
-#include "manifest.h"
-#include "version.h"
-#include "array_list.h"
-#include "bundle.h"
-#include "framework_exports.h"
-
-#ifdef __cplusplus
-extern "C" {
-#endif
-
-module_pt module_create(manifest_pt headerMap, const char *moduleId, bundle_pt bundle);
-
-module_pt module_createFrameworkModule(bundle_pt bundle);
-
-void module_destroy(module_pt module);
-
-FRAMEWORK_EXPORT unsigned int module_hash(void *module);
-
-FRAMEWORK_EXPORT int module_equals(void *module, void *compare);
-
-FRAMEWORK_EXPORT wire_pt module_getWire(module_pt module, const char *serviceName);
-
-FRAMEWORK_EXPORT version_pt module_getVersion(module_pt module);
-
-FRAMEWORK_EXPORT celix_status_t module_getSymbolicName(module_pt module, const char **symbolicName);
-
-FRAMEWORK_EXPORT char *module_getId(module_pt module);
-
-FRAMEWORK_EXPORT linked_list_pt module_getWires(module_pt module);
-
-FRAMEWORK_EXPORT void module_setWires(module_pt module, linked_list_pt wires);
-
-FRAMEWORK_EXPORT bool module_isResolved(module_pt module);
-
-FRAMEWORK_EXPORT void module_setResolved(module_pt module);
-
-FRAMEWORK_EXPORT bundle_pt module_getBundle(module_pt module);
-
-FRAMEWORK_EXPORT linked_list_pt module_getRequirements(module_pt module);
-
-FRAMEWORK_EXPORT linked_list_pt module_getCapabilities(module_pt module);
-
-FRAMEWORK_EXPORT array_list_pt module_getDependentImporters(module_pt module);
-
-FRAMEWORK_EXPORT void module_addDependentImporter(module_pt module, module_pt importer);
-
-FRAMEWORK_EXPORT void module_removeDependentImporter(module_pt module, module_pt importer);
-
-FRAMEWORK_EXPORT array_list_pt module_getDependentRequirers(module_pt module);
-
-FRAMEWORK_EXPORT void module_addDependentRequirer(module_pt module, module_pt requirer);
-
-FRAMEWORK_EXPORT void module_removeDependentRequirer(module_pt module, module_pt requirer);
-
-FRAMEWORK_EXPORT array_list_pt module_getDependents(module_pt module);
-
-#ifdef __cplusplus
-}
-#endif
-
-#endif /* MODULE_H_ */

http://git-wip-us.apache.org/repos/asf/celix/blob/3bce889b/framework/include/requirement.h
----------------------------------------------------------------------
diff --git a/framework/include/requirement.h b/framework/include/requirement.h
deleted file mode 100644
index febc62a..0000000
--- a/framework/include/requirement.h
+++ /dev/null
@@ -1,53 +0,0 @@
-/**
- *Licensed to the 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.  The 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.
- */
-/*
- * requirement.h
- *
- *  \date       Jul 12, 2010
- *  \author    	<a href="mailto:dev@celix.apache.org">Apache Celix Project Team</a>
- *  \copyright	Apache License, Version 2.0
- */
-
-#ifndef REQUIREMENT_H_
-#define REQUIREMENT_H_
-
-typedef struct requirement *requirement_pt;
-
-#include "capability.h"
-#include "hash_map.h"
-#include "version_range.h"
-#ifdef __cplusplus
-extern "C" {
-#endif
-
-celix_status_t requirement_create(hash_map_pt directives, hash_map_pt attributes, requirement_pt *requirement);
-
-celix_status_t requirement_destroy(requirement_pt requirement);
-
-celix_status_t requirement_getVersionRange(requirement_pt requirement, version_range_pt *range);
-
-celix_status_t requirement_getTargetName(requirement_pt requirement, const char **targetName);
-
-celix_status_t requirement_isSatisfied(requirement_pt requirement, capability_pt capability, bool *inRange);
-
-#ifdef __cplusplus
-}
-#endif
-
-#endif /* REQUIREMENT_H_ */

http://git-wip-us.apache.org/repos/asf/celix/blob/3bce889b/framework/include/service_event.h
----------------------------------------------------------------------
diff --git a/framework/include/service_event.h b/framework/include/service_event.h
deleted file mode 100644
index a018b07..0000000
--- a/framework/include/service_event.h
+++ /dev/null
@@ -1,68 +0,0 @@
-/*
- *Licensed to the 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.  The 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.
- */
-/**
- *
- * @defgroup ServiceListener Service Listener
- * @ingroup framework
- * @{
- *
- *  \author    	<a href="mailto:dev@celix.apache.org">Apache Celix Project Team</a>
- *  \date      	January 11, 2012
- *  \copyright	Apache License, Version 2.0
- */
-#ifndef SERVICE_EVENT_H_
-#define SERVICE_EVENT_H_
-#ifdef __cplusplus
-extern "C" {
-#endif
-
-enum serviceEventType {
-	OSGI_FRAMEWORK_SERVICE_EVENT_REGISTERED = 0x00000001,
-	OSGI_FRAMEWORK_SERVICE_EVENT_MODIFIED = 0x00000002,
-	OSGI_FRAMEWORK_SERVICE_EVENT_UNREGISTERING = 0x00000004,
-	OSGI_FRAMEWORK_SERVICE_EVENT_MODIFIED_ENDMATCH = 0x00000008,
-};
-
-typedef enum serviceEventType service_event_type_e;
-
-typedef struct serviceEvent *service_event_pt;
-#ifdef __cplusplus
-}
-#endif
-
-#include "service_reference.h"
-
-#include "service_reference.h"
-#ifdef __cplusplus
-extern "C" {
-#endif
-
-struct serviceEvent {
-	service_reference_pt reference;
-	service_event_type_e type;
-};
-#ifdef __cplusplus
-}
-#endif
-
-#endif /* SERVICE_EVENT_H_ */
-
-/**
- * @}
- */

http://git-wip-us.apache.org/repos/asf/celix/blob/3bce889b/framework/include/service_factory.h
----------------------------------------------------------------------
diff --git a/framework/include/service_factory.h b/framework/include/service_factory.h
deleted file mode 100644
index 80230d1..0000000
--- a/framework/include/service_factory.h
+++ /dev/null
@@ -1,44 +0,0 @@
-/**
- *Licensed to the 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.  The 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.
- */
-#ifndef SERVICE_FACTORY_H_
-#define SERVICE_FACTORY_H_
-
-#include "celix_types.h"
-#include "celix_errno.h"
-#include "service_registration.h"
-#include "bundle.h"
-
-#ifdef __cplusplus
-extern "C" {
-#endif
-
-struct service_factory {
-    void *handle;
-
-    celix_status_t (*getService)(void *handle, celix_bundle_t *bnd, service_registration_pt registration, void **service);
-
-    celix_status_t
-    (*ungetService)(void *handle, celix_bundle_t *bnd, service_registration_pt registration, void **service);
-};
-
-#ifdef __cplusplus
-}
-#endif
-
-#endif /* SERVICE_FACTORY_H_ */

http://git-wip-us.apache.org/repos/asf/celix/blob/3bce889b/framework/include/service_listener.h
----------------------------------------------------------------------
diff --git a/framework/include/service_listener.h b/framework/include/service_listener.h
deleted file mode 100644
index c887ba1..0000000
--- a/framework/include/service_listener.h
+++ /dev/null
@@ -1,55 +0,0 @@
-/*
- *Licensed to the 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.  The 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.
- */
-/**
- *
- * @defgroup ServiceListener Service Listener
- * @ingroup framework
- * @{
- *
- *  \author    	<a href="mailto:dev@celix.apache.org">Apache Celix Project Team</a>
- *  \date      	January 11, 2012
- *  \copyright	Apache License, Version 2.0
- */
-#ifndef SERVICE_LISTENER_H_
-#define SERVICE_LISTENER_H_
-
-typedef struct serviceListener * service_listener_pt;
-
-#include "celix_errno.h"
-#include "service_event.h"
-#ifdef __cplusplus
-extern "C" {
-#endif
-
-struct serviceListener {
-	void *handle;
-
-	celix_status_t (*serviceChanged)(void *listener, service_event_pt event);
-};
-
-#ifdef __cplusplus
-}
-#endif
-
-
-#endif /* SERVICE_LISTENER_H_ */
-
-/**
- * @}
- */

http://git-wip-us.apache.org/repos/asf/celix/blob/3bce889b/framework/include/service_reference.h
----------------------------------------------------------------------
diff --git a/framework/include/service_reference.h b/framework/include/service_reference.h
deleted file mode 100644
index 3d84526..0000000
--- a/framework/include/service_reference.h
+++ /dev/null
@@ -1,75 +0,0 @@
-/**
- *Licensed to the 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.  The 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.
- */
-/*
- * service_reference.h
- *
- *  \date       Jul 20, 2010
- *  \author    	<a href="mailto:dev@celix.apache.org">Apache Celix Project Team</a>
- *  \copyright	Apache License, Version 2.0
- */
-
-#ifndef SERVICE_REFERENCE_H_
-#define SERVICE_REFERENCE_H_
-
-typedef struct serviceReference * service_reference_pt;
-
-#include "celixbool.h"
-#include "array_list.h"
-#include "service_registration.h"
-#include "bundle.h"
-#include "framework_exports.h"
-
-#ifdef __cplusplus
-extern "C" {
-#endif
-
-FRAMEWORK_EXPORT celix_status_t serviceReference_getBundle(service_reference_pt reference, bundle_pt *bundle);
-
-FRAMEWORK_EXPORT bool
-serviceReference_isAssignableTo(service_reference_pt reference, bundle_pt requester, const char *serviceName);
-
-FRAMEWORK_EXPORT celix_status_t
-serviceReference_getProperty(service_reference_pt reference, const char *key, const char **value);
-
-FRAMEWORK_EXPORT celix_status_t
-serviceReference_getPropertyWithDefault(service_reference_pt reference, const char *key, const char* def, const char **value);
-
-FRAMEWORK_EXPORT celix_status_t
-serviceReference_getPropertyKeys(service_reference_pt reference, char **keys[], unsigned int *size);
-
-FRAMEWORK_EXPORT celix_status_t
-serviceReference_getServiceRegistration(service_reference_pt reference, service_registration_pt *registration);
-
-FRAMEWORK_EXPORT celix_status_t
-serviceReference_equals(service_reference_pt reference, service_reference_pt compareTo, bool *equal);
-
-FRAMEWORK_EXPORT unsigned int serviceReference_hashCode(const void *referenceP);
-
-FRAMEWORK_EXPORT int serviceReference_equals2(const void *reference1, const void *reference2);
-
-FRAMEWORK_EXPORT celix_status_t
-serviceReference_compareTo(service_reference_pt reference, service_reference_pt compareTo, int *compare);
-
-FRAMEWORK_EXPORT celix_status_t serviceReference_getUsingBundles(service_reference_pt ref, array_list_pt *out);
-
-#ifdef __cplusplus
-}
-#endif
-
-#endif /* SERVICE_REFERENCE_H_ */

http://git-wip-us.apache.org/repos/asf/celix/blob/3bce889b/framework/include/service_registration.h
----------------------------------------------------------------------
diff --git a/framework/include/service_registration.h b/framework/include/service_registration.h
deleted file mode 100644
index 8cb5f29..0000000
--- a/framework/include/service_registration.h
+++ /dev/null
@@ -1,57 +0,0 @@
-/**
- *Licensed to the 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.  The 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.
- */
-
-
-#ifndef SERVICE_REGISTRATION_H_
-#define SERVICE_REGISTRATION_H_
-
-#include "celixbool.h"
-
-typedef struct serviceRegistration * service_registration_pt;
-typedef struct serviceRegistration service_registration_t;
-
-
-#include "service_registry.h"
-#include "array_list.h"
-#include "bundle.h"
-#include "framework_exports.h"
-
-#ifdef __cplusplus
-extern "C" {
-#endif
-
-FRAMEWORK_EXPORT celix_status_t serviceRegistration_unregister(service_registration_t *registration);
-
-FRAMEWORK_EXPORT celix_status_t
-serviceRegistration_getProperties(service_registration_t *registration, properties_pt *properties);
-
-FRAMEWORK_EXPORT celix_status_t
-serviceRegistration_setProperties(service_registration_t *registration, properties_pt properties);
-
-FRAMEWORK_EXPORT celix_status_t
-serviceRegistration_getServiceName(service_registration_t *registration, const char **serviceName);
-
-FRAMEWORK_EXPORT long
-serviceRegistration_getServiceId(service_registration_t *registration);
-
-#ifdef __cplusplus
-}
-#endif
-
-#endif /* SERVICE_REGISTRATION_H_ */

http://git-wip-us.apache.org/repos/asf/celix/blob/3bce889b/framework/include/service_registry.h
----------------------------------------------------------------------
diff --git a/framework/include/service_registry.h b/framework/include/service_registry.h
deleted file mode 100644
index 9ca4a59..0000000
--- a/framework/include/service_registry.h
+++ /dev/null
@@ -1,115 +0,0 @@
-/**
- *Licensed to the 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.  The 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.
- */
-/*
- * service_registry.h
- *
- *  \date       Aug 6, 2010
- *  \author    	<a href="mailto:dev@celix.apache.org">Apache Celix Project Team</a>
- *  \copyright	Apache License, Version 2.0
- */
-
-#ifndef SERVICE_REGISTRY_H_
-#define SERVICE_REGISTRY_H_
-
-typedef struct celix_serviceRegistry * service_registry_pt;
-typedef struct celix_serviceRegistry celix_service_registry_t;
-
-#include "properties.h"
-#include "filter.h"
-#include "service_factory.h"
-#include "service_event.h"
-#include "array_list.h"
-#include "service_registration.h"
-#include "celix_service_factory.h"
-
-#ifdef __cplusplus
-extern "C" {
-#endif
-
-typedef void (*serviceChanged_function_pt)(framework_pt, service_event_type_e, service_registration_pt, properties_pt);
-
-celix_status_t serviceRegistry_create(framework_pt framework, serviceChanged_function_pt serviceChanged,
-                                      service_registry_pt *registry);
-
-celix_status_t serviceRegistry_destroy(service_registry_pt registry);
-
-celix_status_t
-serviceRegistry_getRegisteredServices(service_registry_pt registry, bundle_pt bundle, array_list_pt *services);
-
-celix_status_t
-serviceRegistry_getServicesInUse(service_registry_pt registry, bundle_pt bundle, array_list_pt *services);
-
-celix_status_t serviceRegistry_registerService(service_registry_pt registry, bundle_pt bundle, const char *serviceName,
-                                               const void *serviceObject, properties_pt dictionary,
-                                               service_registration_pt *registration);
-
-celix_status_t
-serviceRegistry_registerServiceFactory(service_registry_pt registry, bundle_pt bundle, const char *serviceName,
-                                       service_factory_pt factory, properties_pt dictionary,
-                                       service_registration_pt *registration);
-
-celix_status_t
-serviceRegistry_unregisterService(service_registry_pt registry, bundle_pt bundle, service_registration_pt registration);
-
-celix_status_t serviceRegistry_clearServiceRegistrations(service_registry_pt registry, bundle_pt bundle);
-
-celix_status_t serviceRegistry_getServiceReference(service_registry_pt registry, bundle_pt bundle,
-                                                   service_registration_pt registration,
-                                                   service_reference_pt *reference);
-
-celix_status_t
-serviceRegistry_getServiceReferences(service_registry_pt registry, bundle_pt bundle, const char *serviceName,
-                                     filter_pt filter, array_list_pt *references);
-
-celix_status_t
-serviceRegistry_retainServiceReference(service_registry_pt registry, bundle_pt bundle, service_reference_pt reference);
-
-celix_status_t
-serviceRegistry_ungetServiceReference(service_registry_pt registry, bundle_pt bundle, service_reference_pt reference);
-
-celix_status_t
-serviceRegistry_getService(service_registry_pt registry, bundle_pt bundle, service_reference_pt reference,
-                           const void **service);
-
-celix_status_t
-serviceRegistry_ungetService(service_registry_pt registry, bundle_pt bundle, service_reference_pt reference,
-                             bool *result);
-
-celix_status_t serviceRegistry_clearReferencesFor(service_registry_pt registry, bundle_pt bundle);
-
-celix_status_t serviceRegistry_getListenerHooks(service_registry_pt registry, bundle_pt bundle, array_list_pt *hooks);
-
-celix_status_t
-serviceRegistry_servicePropertiesModified(service_registry_pt registry, service_registration_pt registration,
-                                          properties_pt oldprops);
-
-celix_status_t
-celix_serviceRegistry_registerServiceFactory(
-        celix_service_registry_t *reg,
-        const celix_bundle_t *bnd,
-        const char *serviceName,
-        celix_service_factory_t *factory,
-        celix_properties_t* props,
-        service_registration_t **registration);
-
-#ifdef __cplusplus
-}
-#endif
-
-#endif /* SERVICE_REGISTRY_H_ */

http://git-wip-us.apache.org/repos/asf/celix/blob/3bce889b/framework/include/service_tracker.h
----------------------------------------------------------------------
diff --git a/framework/include/service_tracker.h b/framework/include/service_tracker.h
deleted file mode 100644
index db65776..0000000
--- a/framework/include/service_tracker.h
+++ /dev/null
@@ -1,142 +0,0 @@
-/**
- *Licensed to the 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.  The 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.
- */
-/*
- * service_tracker.h
- *
- *  \date       Apr 20, 2010
- *  \author    	<a href="mailto:dev@celix.apache.org">Apache Celix Project Team</a>
- *  \copyright	Apache License, Version 2.0
- */
-
-#ifndef SERVICE_TRACKER_H_
-#define SERVICE_TRACKER_H_
-
-#include "service_listener.h"
-#include "array_list.h"
-#include "service_tracker_customizer.h"
-#include "framework_exports.h"
-#include "bundle_context.h"
-#include "celix_bundle_context.h"
-
-
-#ifdef __cplusplus
-extern "C" {
-#endif
-
-typedef struct celix_serviceTracker celix_service_tracker_t;
-
-typedef struct celix_serviceTracker *service_tracker_pt;
-typedef struct celix_serviceTracker service_tracker_t;
-
-FRAMEWORK_EXPORT celix_status_t
-serviceTracker_create(bundle_context_t *ctx, const char *service, service_tracker_customizer_pt customizer,
-                      service_tracker_t **tracker);
-
-FRAMEWORK_EXPORT celix_status_t
-serviceTracker_createWithFilter(bundle_context_t *ctx, const char *filter, service_tracker_customizer_pt customizer,
-                                service_tracker_t **tracker);
-
-FRAMEWORK_EXPORT celix_status_t serviceTracker_open(service_tracker_t *tracker);
-
-FRAMEWORK_EXPORT celix_status_t serviceTracker_close(service_tracker_t *tracker);
-
-FRAMEWORK_EXPORT celix_status_t serviceTracker_destroy(service_tracker_t *tracker);
-
-FRAMEWORK_EXPORT service_reference_pt serviceTracker_getServiceReference(service_tracker_t *tracker);
-
-FRAMEWORK_EXPORT array_list_pt serviceTracker_getServiceReferences(service_tracker_t *tracker);
-
-FRAMEWORK_EXPORT void *serviceTracker_getService(service_tracker_t *tracker);
-
-FRAMEWORK_EXPORT array_list_pt serviceTracker_getServices(service_tracker_t *tracker);
-
-FRAMEWORK_EXPORT void *serviceTracker_getServiceByReference(service_tracker_t *tracker, service_reference_pt reference);
-
-FRAMEWORK_EXPORT void serviceTracker_serviceChanged(service_listener_pt listener, service_event_pt event);
-
-
-
-/**********************************************************************************************************************
- **********************************************************************************************************************
- * Updated API
- **********************************************************************************************************************
- **********************************************************************************************************************/
-
-/**
- * Creates and starts (open) a service tracker.
- * Note that is different from the serviceTracker_create function, because is also starts the service tracker
- */
-celix_service_tracker_t* celix_serviceTracker_create(
-        bundle_context_t *ctx,
-        const char *serviceName,
-        const char *versionRange,
-        const char *filter
-
-);
-
-/**
- * Creates and starts (open) a service tracker.
- * Note that is different from the serviceTracker_create function, because is also starts the service tracker
- */
-celix_service_tracker_t* celix_serviceTracker_createWithOptions(
-        bundle_context_t *ctx,
-        const celix_service_tracking_options_t *opts
-);
-
-
-/**
- * Stops (close) and destroys a service tracker.
- * Note that is different from the serviceTracker_destroy function, because is also stops the service tracker
- */
-void celix_serviceTracker_destroy(celix_service_tracker_t *tracker);
-
-/**
- * Use the highest ranking service of the service tracker.
- * If a serviceName is provided this will also be checked.
- * No match -> no call to use.
- *
- * @return bool     if the service if found and use has been called.
- */
-bool celix_serviceTracker_useHighestRankingService(
-        celix_service_tracker_t *tracker,
-        const char *serviceName /*sanity*/,
-        void *callbackHandle,
-        void (*use)(void *handle, void *svc),
-        void (*useWithProperties)(void *handle, void *svc, const celix_properties_t *props),
-        void (*useWithOwner)(void *handle, void *svc, const celix_properties_t *props, const celix_bundle_t *owner)
-);
-
-
-/**
- * Calls the use callback for every services found by this tracker.
- */
-void celix_serviceTracker_useServices(
-        service_tracker_t *tracker,
-        const char* serviceName /*sanity*/,
-        void *callbackHandle,
-        void (*use)(void *handle, void *svc),
-        void (*useWithProperties)(void *handle, void *svc, const celix_properties_t *props),
-        void (*useWithOwner)(void *handle, void *svc, const celix_properties_t *props, const celix_bundle_t *owner)
-);
-
-#ifdef __cplusplus
-}
-#endif
-
-#endif /* SERVICE_TRACKER_H_ */

http://git-wip-us.apache.org/repos/asf/celix/blob/3bce889b/framework/include/service_tracker_customizer.h
----------------------------------------------------------------------
diff --git a/framework/include/service_tracker_customizer.h b/framework/include/service_tracker_customizer.h
deleted file mode 100644
index 19672d8..0000000
--- a/framework/include/service_tracker_customizer.h
+++ /dev/null
@@ -1,78 +0,0 @@
-/**
- *Licensed to the 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.  The 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.
- */
-/*
- * service_tracker_customizer.h
- *
- *  \date       Nov 15, 2012
- *  \author     <a href="mailto:dev@celix.apache.org">Apache Celix Project Team</a>
- *  \copyright  Apache License, Version 2.0
- */
-
-
-#ifndef service_tracker_customizer_t_H_
-#define service_tracker_customizer_t_H_
-
-#include <celix_errno.h>
-#include <service_reference.h>
-
-#ifdef __cplusplus
-extern "C" {
-#endif
-
-typedef celix_status_t (*adding_callback_pt)(void *handle, service_reference_pt reference, void **service);
-
-typedef celix_status_t (*added_callback_pt)(void *handle, service_reference_pt reference, void *service);
-
-typedef celix_status_t (*modified_callback_pt)(void *handle, service_reference_pt reference, void *service);
-
-typedef celix_status_t (*removed_callback_pt)(void *handle, service_reference_pt reference, void *service);
-
-typedef struct serviceTrackerCustomizer *service_tracker_customizer_pt;
-typedef struct serviceTrackerCustomizer service_tracker_customizer_t;
-
-
-FRAMEWORK_EXPORT celix_status_t serviceTrackerCustomizer_create(void *handle,
-																adding_callback_pt addingFunction,
-																added_callback_pt addedFunction,
-																modified_callback_pt modifiedFunction,
-																removed_callback_pt removedFunction,
-																service_tracker_customizer_pt *customizer);
-
-FRAMEWORK_EXPORT celix_status_t serviceTrackerCustomizer_destroy(service_tracker_customizer_pt customizer);
-
-FRAMEWORK_EXPORT celix_status_t
-serviceTrackerCustomizer_getHandle(service_tracker_customizer_pt customizer, void **handle);
-
-FRAMEWORK_EXPORT celix_status_t
-serviceTrackerCustomizer_getAddingFunction(service_tracker_customizer_pt customizer, adding_callback_pt *function);
-
-FRAMEWORK_EXPORT celix_status_t
-serviceTrackerCustomizer_getAddedFunction(service_tracker_customizer_pt customizer, added_callback_pt *function);
-
-FRAMEWORK_EXPORT celix_status_t
-serviceTrackerCustomizer_getModifiedFunction(service_tracker_customizer_pt customizer, modified_callback_pt *function);
-
-FRAMEWORK_EXPORT celix_status_t
-serviceTrackerCustomizer_getRemovedFunction(service_tracker_customizer_pt customizer, removed_callback_pt *function);
-
-#ifdef __cplusplus
-}
-#endif
-
-#endif /* service_tracker_customizer_t_H_ */

http://git-wip-us.apache.org/repos/asf/celix/blob/3bce889b/framework/include/wire.h
----------------------------------------------------------------------
diff --git a/framework/include/wire.h b/framework/include/wire.h
deleted file mode 100644
index 9bb9e02..0000000
--- a/framework/include/wire.h
+++ /dev/null
@@ -1,120 +0,0 @@
-/**
- *Licensed to the 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.  The 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.
- */
-/*
- * wire.h
- *
- *  \date       Jul 12, 2010
- *  \author    	<a href="mailto:dev@celix.apache.org">Apache Celix Project Team</a>
- *  \copyright	Apache License, Version 2.0
- */
-
-#ifndef WIRE_H_
-#define WIRE_H_
-
-typedef struct wire *wire_pt;
-
-#include "requirement.h"
-#include "capability.h"
-#include "module.h"
-#include "linked_list.h"
-#include "module.h"
-
-#ifdef __cplusplus
-extern "C" {
-#endif
-
-/**
- * @defgroup Version Version
- * @ingroup framework
- * @{
- */
-
-/**
- * Create a wire between two modules using a requirement and capability.
- *
- * @param importer The importer module of the wire.
- * @param requirement The requirement of the importer.
- * @param exporter The exporter module of the wire.
- * @param capability The capability of the wire.
- * @param wire The created wire.
- * @return Status code indication failure or success:
- * 		- CELIX_SUCCESS when no errors are encountered.
- * 		- CELIX_ENOMEM If allocating memory for <code>wire</code> failed.
- */
-celix_status_t wire_create(module_pt importer, requirement_pt requirement,
-						   module_pt exporter, capability_pt capability, wire_pt *wire);
-
-/**
- * Getter for the capability of the exporting module.
- *
- * @param wire The wire to get the capability from.
- * @param capability The capability
- * @return Status code indication failure or success:
- *      - CELIX_SUCCESS when no errors are encountered.
- */
-celix_status_t wire_destroy(wire_pt wire);
-
-/**
- * Getter for the capability of the exporting module.
- *
- * @param wire The wire to get the capability from.
- * @param capability The capability
- * @return Status code indication failure or success:
- * 		- CELIX_SUCCESS when no errors are encountered.
- */
-celix_status_t wire_getCapability(wire_pt wire, capability_pt *capability);
-
-/**
- * Getter for the requirement of the importing module.
- *
- * @param wire The wire to get the requirement from.
- * @param requirement The requirement
- * @return Status code indication failure or success:
- * 		- CELIX_SUCCESS when no errors are encountered.
- */
-celix_status_t wire_getRequirement(wire_pt wire, requirement_pt *requirement);
-
-/**
- * Getter for the importer of the wire.
- *
- * @param wire The wire to get the importer from.
- * @param importer The importing module.
- * @return Status code indication failure or success:
- * 		- CELIX_SUCCESS when no errors are encountered.
- */
-celix_status_t wire_getImporter(wire_pt wire, module_pt *importer);
-
-/**
- * Getter for the exporter of the wire.
- *
- * @param wire The wire to get the exporter from.
- * @param exporter The exporting module.
- * @return Status code indication failure or success:
- * 		- CELIX_SUCCESS when no errors are encountered.
- */
-celix_status_t wire_getExporter(wire_pt wire, module_pt *exporter);
-
-/**
- * @}
- */
-#ifdef __cplusplus
-}
-#endif
-
-#endif /* WIRE_H_ */

http://git-wip-us.apache.org/repos/asf/celix/blob/3bce889b/framework/private/integration-test/CMakeLists.txt
----------------------------------------------------------------------
diff --git a/framework/private/integration-test/CMakeLists.txt b/framework/private/integration-test/CMakeLists.txt
deleted file mode 100644
index 8dd80e6..0000000
--- a/framework/private/integration-test/CMakeLists.txt
+++ /dev/null
@@ -1,19 +0,0 @@
-# Licensed to the 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.  The 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.
-
-add_subdirectory(test_bundle1)
-add_subdirectory(test_launcher)
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/celix/blob/3bce889b/framework/private/integration-test/test_bundle1/CMakeLists.txt
----------------------------------------------------------------------
diff --git a/framework/private/integration-test/test_bundle1/CMakeLists.txt b/framework/private/integration-test/test_bundle1/CMakeLists.txt
deleted file mode 100644
index c766b06..0000000
--- a/framework/private/integration-test/test_bundle1/CMakeLists.txt
+++ /dev/null
@@ -1,20 +0,0 @@
-# Licensed to the 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.  The 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.
-
-add_celix_bundle(test_bundle1 SOURCES src/activator VERSION 0.0.1)
-include_directories("${PROJECT_SOURCE_DIR}/utils/public/include")
-target_link_libraries(test_bundle1 celix_framework)

http://git-wip-us.apache.org/repos/asf/celix/blob/3bce889b/framework/private/integration-test/test_bundle1/src/activator.c
----------------------------------------------------------------------
diff --git a/framework/private/integration-test/test_bundle1/src/activator.c b/framework/private/integration-test/test_bundle1/src/activator.c
deleted file mode 100644
index 4d5261f..0000000
--- a/framework/private/integration-test/test_bundle1/src/activator.c
+++ /dev/null
@@ -1,78 +0,0 @@
-/**
- *Licensed to the 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.  The 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.
- */
-/*
- * activator.c
- *
- *  \date       Aug 20, 2010
- *  \author    	<a href="mailto:dev@celix.apache.org">Apache Celix Project Team</a>
- *  \copyright	Apache License, Version 2.0
- */
-#include <stdlib.h>
-#include <stdio.h>
-
-#include "bundle_activator.h"
-#include "bundle_context.h"
-#include "framework_listener.h"
-
-struct userData {
-    framework_listener_pt listener;
-};
-
-celix_status_t test_frameworkEvent(void *listener, framework_event_pt event);
-
-celix_status_t bundleActivator_create(bundle_context_pt context, void **userData) {
-	*userData = calloc(1, sizeof(struct userData));
-	if(*userData == NULL){
-		return CELIX_ENOMEM;
-	}
-	return CELIX_SUCCESS;
-}
-
-celix_status_t bundleActivator_start(void * userData, bundle_context_pt context) {
-	struct userData * activator = (struct userData *) userData;
-
-	activator->listener = calloc(1, sizeof(*activator->listener));
-   activator->listener->handle = activator;
-   activator->listener->frameworkEvent = test_frameworkEvent;
-   bundleContext_addFrameworkListener(context, activator->listener);
-
-	return CELIX_SUCCESS;
-}
-
-celix_status_t bundleActivator_stop(void * userData, bundle_context_pt context) {
-	struct userData * data = (struct userData *) userData;
-
-	// do not remove listener, fw should remove it.
-
-	return CELIX_SUCCESS;
-}
-
-celix_status_t bundleActivator_destroy(void * userData, bundle_context_pt context) {
-	struct userData * activator = (struct userData *) userData;
-	if(activator->listener != NULL){
-		free(activator->listener);
-	}
-
-	free(activator);
-	return CELIX_SUCCESS;
-}
-
-celix_status_t test_frameworkEvent(void *listener, framework_event_pt event) {
-    return CELIX_SUCCESS;
-}

http://git-wip-us.apache.org/repos/asf/celix/blob/3bce889b/framework/private/integration-test/test_launcher/CMakeLists.txt
----------------------------------------------------------------------
diff --git a/framework/private/integration-test/test_launcher/CMakeLists.txt b/framework/private/integration-test/test_launcher/CMakeLists.txt
deleted file mode 100644
index 54aa43f..0000000
--- a/framework/private/integration-test/test_launcher/CMakeLists.txt
+++ /dev/null
@@ -1,22 +0,0 @@
-# Licensed to the 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.  The 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.
-add_executable(test_launcher src/launcher)
-
-target_link_libraries(test_launcher celix_framework)
-include_directories("${PROJECT_SOURCE_DIR}/utils/public/include")
-include_directories("${PROJECT_SOURCE_DIR}/framework/public/include")
-include_directories("${PROJECT_SOURCE_DIR}/framework/private/include")

http://git-wip-us.apache.org/repos/asf/celix/blob/3bce889b/framework/private/integration-test/test_launcher/src/launcher.c
----------------------------------------------------------------------
diff --git a/framework/private/integration-test/test_launcher/src/launcher.c b/framework/private/integration-test/test_launcher/src/launcher.c
deleted file mode 100644
index 414debc..0000000
--- a/framework/private/integration-test/test_launcher/src/launcher.c
+++ /dev/null
@@ -1,94 +0,0 @@
-/**
- *Licensed to the 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.  The 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.
- */
-/*
- * launcher.c
- *
- *  \date       Mar 23, 2010
- *  \author    	<a href="mailto:dev@celix.apache.org">Apache Celix Project Team</a>
- *  \copyright	Apache License, Version 2.0
- */
-#include <stdio.h>
-#include <string.h>
-#include <stdlib.h>
-#include <signal.h>
-#include <apr_general.h>
-#include <unistd.h>
-
-#include "framework_private.h"
-#include "properties.h"
-#include "bundle_context.h"
-#include "bundle.h"
-#include "linked_list_iterator.h"
-#include "celix_log.h"
-
-int main(void) {
-	apr_status_t rv = APR_SUCCESS;
-	apr_status_t s = APR_SUCCESS;
-	properties_pt config = NULL;
-	char *autoStart = NULL;
-    apr_pool_t *pool = NULL;
-    bundle_pt fwBundle = NULL;
-
-	rv = apr_initialize();
-    if (rv != APR_SUCCESS) {
-        return CELIX_START_ERROR;
-    }
-    apr_pool_t *memoryPool;
-    s = apr_pool_create(&memoryPool, NULL);
-    if (s != APR_SUCCESS) {
-        return CELIX_START_ERROR;
-    }
-
-    struct framework * framework = NULL;
-    celix_status_t status = CELIX_SUCCESS;
-    status = framework_create(&framework, memoryPool, config);
-    if (status == CELIX_SUCCESS) {
-		status = fw_init(framework);
-		if (status == CELIX_SUCCESS) {
-            // Start the system bundle
-            framework_getFrameworkBundle(framework, &fwBundle);
-            bundle_start(fwBundle);
-            bundle_context_pt context = NULL;
-            bundle_getContext(fwBundle, &context);
-
-            // do some stuff
-            bundle_pt bundle = NULL;
-            status = CELIX_DO_IF(status, bundleContext_installBundle(context, "../test_bundle1/test_bundle1.zip", &bundle));
-            status = CELIX_DO_IF(status, bundle_start(bundle));
-
-            // Stop the system bundle, sleep a bit to let stuff settle down
-            sleep(5);
-            bundle_stop(fwBundle);
-
-            framework_destroy(framework);
-		}
-    }
-
-    if (status != CELIX_SUCCESS) {
-        printf("Problem creating framework\n");
-    }
-
-	apr_pool_destroy(memoryPool);
-	apr_terminate();
-
-	printf("LAUNCHER: Exit\n");
-
-    return 0;
-}
-

http://git-wip-us.apache.org/repos/asf/celix/blob/3bce889b/framework/private/mock/attribute_mock.c
----------------------------------------------------------------------
diff --git a/framework/private/mock/attribute_mock.c b/framework/private/mock/attribute_mock.c
deleted file mode 100644
index c71d8da..0000000
--- a/framework/private/mock/attribute_mock.c
+++ /dev/null
@@ -1,59 +0,0 @@
-/**
- *Licensed to the 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.  The 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.
- */
-/*
- * attribute_mock.c
- *
- *  \date       Feb 11, 2013
- *  \author     <a href="mailto:dev@celix.apache.org">Apache Celix Project Team</a>
- *  \copyright  Apache License, Version 2.0
- */
-#include "CppUTestExt/MockSupport_c.h"
-
-#include "attribute.h"
-
-celix_status_t attribute_create(char * key, char * value, attribute_pt *attribute) {
-	mock_c()->actualCall("attribute_create")
-			->withStringParameters("key", key)
-			->withStringParameters("value", value)
-			->withOutputParameter("attribute", (void **) attribute);
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t attribute_destroy(attribute_pt attribute) {
-    mock_c()->actualCall("attribute_destroy")
-    		->withPointerParameters("attribute", attribute);
-    return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t attribute_getKey(attribute_pt attribute, char **key) {
-	mock_c()->actualCall("attribute_getKey")
-			->withPointerParameters("attribute", attribute)
-			->withOutputParameter("key", (const char **) key);
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t attribute_getValue(attribute_pt attribute, char **value) {
-	mock_c()->actualCall("attribute_getValue")
-			->withPointerParameters("attribute", attribute)
-			->withOutputParameter("value", (const char **) value);
-	return mock_c()->returnValue().value.intValue;
-}
-
-
-

http://git-wip-us.apache.org/repos/asf/celix/blob/3bce889b/framework/private/mock/bundle_archive_mock.c
----------------------------------------------------------------------
diff --git a/framework/private/mock/bundle_archive_mock.c b/framework/private/mock/bundle_archive_mock.c
deleted file mode 100644
index b352366..0000000
--- a/framework/private/mock/bundle_archive_mock.c
+++ /dev/null
@@ -1,164 +0,0 @@
-/**
- *Licensed to the 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.  The 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.
- */
-/*
- * bundle_archive_mock.c
- *
- *  \date       Feb 11, 2013
- *  \author     <a href="mailto:dev@celix.apache.org">Apache Celix Project Team</a>
- *  \copyright  Apache License, Version 2.0
- */
-#include "CppUTestExt/MockSupport_c.h"
-
-#include "bundle_archive.h"
-
-celix_status_t bundleArchive_create(const char * archiveRoot, long id, const char * location, const char *inputFile, bundle_archive_pt *bundle_archive) {
-	mock_c()->actualCall("bundleArchive_create")
-			->withStringParameters("archiveRoot", archiveRoot)
-			->withIntParameters("id", id)
-			->withStringParameters("location", location)
-			->withStringParameters("inputFile", inputFile)
-			->withOutputParameter("bundle_archive", (void **) bundle_archive);
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleArchive_createSystemBundleArchive(bundle_archive_pt *bundle_archive) {
-	mock_c()->actualCall("bundleArchive_createSystemBundleArchive")
-			->withOutputParameter("bundle_archive", (void **) bundle_archive);
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleArchive_recreate(const char * archiveRoot, bundle_archive_pt *bundle_archive) {
-	mock_c()->actualCall("bundleArchive_recreate")
-			->withStringParameters("archiveRoot", archiveRoot)
-			->withOutputParameter("bundle_archive", (void **) bundle_archive);
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleArchive_destroy(bundle_archive_pt archive) {
-    mock_c()->actualCall("bundleArchive_destroy");
-    return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleArchive_getId(bundle_archive_pt archive, long *id) {
-	mock_c()->actualCall("bundleArchive_getId")
-			->withPointerParameters("archive", archive)
-			->withOutputParameter("id", id);
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleArchive_getLocation(bundle_archive_pt archive, const char **location) {
-	mock_c()->actualCall("bundleArchive_getLocation")
-			->withPointerParameters("archive", archive)
-			->withOutputParameter("location", location);
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleArchive_getArchiveRoot(bundle_archive_pt archive, const char **archiveRoot) {
-	mock_c()->actualCall("bundleArchive_getArchiveRoot")
-			->withPointerParameters("archive", archive)
-			->withOutputParameter("archiveRoot", archiveRoot);
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleArchive_revise(bundle_archive_pt archive, const char * location, const char *inputFile) {
-	mock_c()->actualCall("bundleArchive_revise")
-			->withPointerParameters("archive", archive)
-			->withStringParameters("location", location)
-			->withStringParameters("inputFile", inputFile);
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleArchive_rollbackRevise(bundle_archive_pt archive, bool *rolledback) {
-	mock_c()->actualCall("bundleArchive_rollbackRevise")
-			->withPointerParameters("archive", archive)
-			->withOutputParameter("rolledback", rolledback);
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleArchive_getRevision(bundle_archive_pt archive, long revNr, bundle_revision_pt *revision) {
-	mock_c()->actualCall("bundleArchive_getRevision")
-			->withPointerParameters("archive", archive)
-			->withLongIntParameters("revNr", revNr)
-			->withOutputParameter("revision", revision);
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleArchive_getCurrentRevision(bundle_archive_pt archive, bundle_revision_pt *revision) {
-	mock_c()->actualCall("bundleArchive_getCurrentRevision")
-        ->withPointerParameters("archive", archive)
-        ->withOutputParameter("revision", (void **) revision);
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleArchive_getCurrentRevisionNumber(bundle_archive_pt archive, long *revisionNumber) {
-	mock_c()->actualCall("bundleArchive_getCurrentRevisionNumber")
-			->withPointerParameters("archive", archive)
-			->withOutputParameter("revisionNumber", revisionNumber);
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleArchive_getRefreshCount(bundle_archive_pt archive, long *refreshCount) {
-	mock_c()->actualCall("bundleArchive_getRefreshCount")
-			->withPointerParameters("archive", archive)
-			->withOutputParameter("refreshCount", refreshCount);
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleArchive_setRefreshCount(bundle_archive_pt archive) {
-	mock_c()->actualCall("bundleArchive_setRefreshCount");
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleArchive_close(bundle_archive_pt archive) {
-	mock_c()->actualCall("bundleArchive_close")
-			->withPointerParameters("archive", archive);
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleArchive_closeAndDelete(bundle_archive_pt archive) {
-	mock_c()->actualCall("bundleArchive_closeAndDelete");
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleArchive_setLastModified(bundle_archive_pt archive, time_t lastModifiedTime) {
-	mock_c()->actualCall("bundleArchive_setLastModified");
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleArchive_getLastModified(bundle_archive_pt archive, time_t *lastModified) {
-	mock_c()->actualCall("bundleArchive_getLastModified")
-			->withPointerParameters("archive", archive)
-			->withOutputParameter("lastModified", lastModified);
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleArchive_setPersistentState(bundle_archive_pt archive, bundle_state_e state) {
-	mock_c()->actualCall("bundleArchive_setPersistentState")
-			->withPointerParameters("archive", archive)
-			->withIntParameters("state", state);
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleArchive_getPersistentState(bundle_archive_pt archive, bundle_state_e *state) {
-	mock_c()->actualCall("bundleArchive_getPersistentState")
-			->withPointerParameters("archive", archive)
-			->withOutputParameter("state", state);
-	return mock_c()->returnValue().value.intValue;
-}
-

http://git-wip-us.apache.org/repos/asf/celix/blob/3bce889b/framework/private/mock/bundle_cache_mock.c
----------------------------------------------------------------------
diff --git a/framework/private/mock/bundle_cache_mock.c b/framework/private/mock/bundle_cache_mock.c
deleted file mode 100644
index 169a256..0000000
--- a/framework/private/mock/bundle_cache_mock.c
+++ /dev/null
@@ -1,66 +0,0 @@
-/**
- *Licensed to the 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.  The 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.
- */
-/*
- * bundle_cache_mock.c
- *
- *  \date       Feb 11, 2013
- *  \author     <a href="mailto:dev@celix.apache.org">Apache Celix Project Team</a>
- *  \copyright  Apache License, Version 2.0
- */
-#include "CppUTestExt/MockSupport_c.h"
-
-#include "bundle_cache.h"
-
-celix_status_t bundleCache_create(properties_pt configurationMap, bundle_cache_pt *bundle_cache) {
-	mock_c()->actualCall("bundleCache_create")
-		->withPointerParameters("configurationMap", configurationMap)
-		->withOutputParameter("bundle_cache", bundle_cache);
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleCache_destroy(bundle_cache_pt *cache) {
-	mock_c()->actualCall("bundleCache_destroy");
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleCache_getArchives(bundle_cache_pt cache, array_list_pt *archives) {
-	mock_c()->actualCall("bundleCache_getArchives")
-			->withPointerParameters("cache", cache)
-			->withOutputParameter("archives", archives);
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleCache_createArchive(bundle_cache_pt cache, long id, const char * location, const char *inputFile, bundle_archive_pt *archive) {
-	mock_c()->actualCall("bundleCache_createArchive")
-			->withPointerParameters("cache", cache)
-			->withLongIntParameters("id", id)
-			->withStringParameters("location", location)
-			->withStringParameters("inputFile", inputFile)
-			->withOutputParameter("archive", archive);
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleCache_delete(bundle_cache_pt cache) {
-	mock_c()->actualCall("bundleCache_delete");
-	return mock_c()->returnValue().value.intValue;
-}
-
-
-
-

http://git-wip-us.apache.org/repos/asf/celix/blob/3bce889b/framework/private/mock/bundle_context_mock.c
----------------------------------------------------------------------
diff --git a/framework/private/mock/bundle_context_mock.c b/framework/private/mock/bundle_context_mock.c
deleted file mode 100644
index 7c0b6e6..0000000
--- a/framework/private/mock/bundle_context_mock.c
+++ /dev/null
@@ -1,363 +0,0 @@
-/**
- *Licensed to the 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.  The 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.
- */
-/*
- * bundle_context_mock.c
- *
- *  \date       Feb 6, 2013
- *  \author     <a href="mailto:dev@celix.apache.org">Apache Celix Project Team</a>
- *  \copyright  Apache License, Version 2.0
- */
-#include <CppUTestExt/MockSupport_c.h>
-#include "CppUTestExt/MockSupport_c.h"
-
-#include "bundle_context.h"
-#include "celix_bundle_context.h"
-
-celix_status_t bundleContext_create(framework_pt framework, framework_logger_pt logger, bundle_pt bundle, bundle_context_pt *bundle_context) {
-	mock_c()->actualCall("bundleContext_create")
-			->withPointerParameters("framework", framework)
-			->withPointerParameters("logger", logger)
-			->withPointerParameters("bundle", bundle)
-			->withOutputParameter("bundle_context", (void **) bundle_context);
-	return mock_c()->returnValue().value.intValue;
-}
-celix_status_t bundleContext_destroy(bundle_context_pt context) {
-	return CELIX_SUCCESS;
-}
-
-celix_status_t bundleContext_getBundle(bundle_context_pt context, bundle_pt *bundle) {
-	mock_c()->actualCall("bundleContext_getBundle")
-			->withPointerParameters("context", context)
-			->withOutputParameter("bundle", (void **) bundle);
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleContext_getFramework(bundle_context_pt context, framework_pt *framework) {
-	mock_c()->actualCall("bundleContext_getFramework")
-			->withPointerParameters("context", context)
-			->withOutputParameter("framework", (void **) framework);
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleContext_installBundle(bundle_context_pt context, const char * location, bundle_pt *bundle) {
-	mock_c()->actualCall("bundleContext_installBundle")
-			->withPointerParameters("context", context)
-			->withStringParameters("location", location)
-			->withOutputParameter("bundle", (void **) bundle);
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleContext_installBundle2(bundle_context_pt context, const char * location, const char *inputFile, bundle_pt *bundle) {
-	mock_c()->actualCall("bundleContext_installBundle2")
-			->withPointerParameters("context", context)
-			->withStringParameters("location", location)
-			->withStringParameters("inputFile", inputFile)
-			->withOutputParameter("bundle", (void **) bundle);
-	return mock_c()->returnValue().value.intValue;
-}
-
-
-celix_status_t bundleContext_registerService(bundle_context_pt context, const char * serviceName, const void * svcObj,
-        properties_pt properties, service_registration_pt *service_registration) {
-	mock_c()->actualCall("bundleContext_registerService")
-			->withPointerParameters("context", context)
-			->withStringParameters("serviceName", serviceName)
-			->withPointerParameters("svcObj", (void*)svcObj)
-			->withPointerParameters("properties", properties)
-			->withOutputParameter("service_registration", (void **) service_registration);
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleContext_registerServiceFactory(bundle_context_pt context, const char * serviceName, service_factory_pt factory,
-        properties_pt properties, service_registration_pt *service_registration) {
-	mock_c()->actualCall("bundleContext_registerServiceFactory")
-			->withPointerParameters("context", context)
-			->withStringParameters("serviceName", serviceName)
-			->withPointerParameters("factory", factory)
-			->withPointerParameters("properties", properties)
-			->withOutputParameter("service_registration", (void **) service_registration);
-	return mock_c()->returnValue().value.intValue;
-}
-
-
-celix_status_t bundleContext_getServiceReferences(bundle_context_pt context, const char * serviceName, const char * filter, array_list_pt *service_references) {
-	mock_c()->actualCall("bundleContext_getServiceReferences")
-			->withPointerParameters("context", context)
-			->withStringParameters("serviceName", serviceName)
-			->withStringParameters("filter", filter)
-			->withOutputParameter("service_references", (void **) service_references);
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleContext_getServiceReference(bundle_context_pt context, const char * serviceName, service_reference_pt *service_reference) {
-	mock_c()->actualCall("bundleContext_getServiceReference")
-			->withPointerParameters("context", context)
-			->withStringParameters("serviceName", serviceName)
-			->withOutputParameter("service_reference", (void **) service_reference);
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleContext_retainServiceReference(bundle_context_pt context, service_reference_pt reference) {
-    mock_c()->actualCall("bundleContext_retainServiceReference")
-            ->withPointerParameters("context", context)
-            ->withPointerParameters("reference", reference);
-    return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleContext_ungetServiceReference(bundle_context_pt context, service_reference_pt reference) {
-    mock_c()->actualCall("bundleContext_ungetServiceReference")
-            ->withPointerParameters("context", context)
-            ->withPointerParameters("reference", reference);
-    return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleContext_getService(bundle_context_pt context, service_reference_pt reference, void **service_instance) {
-	mock_c()->actualCall("bundleContext_getService")
-			->withPointerParameters("context", context)
-			->withPointerParameters("reference", reference)
-			->withOutputParameter("service_instance", (void **) service_instance);
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleContext_ungetService(bundle_context_pt context, service_reference_pt reference, bool *result) {
-	mock_c()->actualCall("bundleContext_ungetService")
-			->withPointerParameters("context", context)
-			->withPointerParameters("reference", reference)
-			->withOutputParameter("result", (int *) result);
-	return mock_c()->returnValue().value.intValue;
-}
-
-
-celix_status_t bundleContext_getBundles(bundle_context_pt context, array_list_pt *bundles) {
-	mock_c()->actualCall("bundleContext_getBundles")
-			->withPointerParameters("context", context)
-			->withOutputParameter("bundles", bundles);
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleContext_getBundleById(bundle_context_pt context, long id, bundle_pt *bundle) {
-	mock_c()->actualCall("bundleContext_getBundleById")
-			->withPointerParameters("context", context)
-			->withLongIntParameters("id", id)
-			->withOutputParameter("bundle", bundle);
-	return mock_c()->returnValue().value.intValue;
-}
-
-
-celix_status_t bundleContext_addServiceListener(bundle_context_pt context, service_listener_pt listener, const char * filter) {
-	mock_c()->actualCall("bundleContext_addServiceListener")
-		->withPointerParameters("context", context)
-		->withPointerParameters("listener", listener)
-		->withStringParameters("filter", filter);
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleContext_removeServiceListener(bundle_context_pt context, service_listener_pt listener) {
-	mock_c()->actualCall("bundleContext_removeServiceListener")
-		->withPointerParameters("context", context)
-		->withPointerParameters("listener", listener);
-	return mock_c()->returnValue().value.intValue;
-}
-
-
-celix_status_t bundleContext_addBundleListener(bundle_context_pt context, bundle_listener_pt listener) {
-	mock_c()->actualCall("bundleContext_addBundleListener");
-	return mock_c()->returnValue().value.intValue;
-}
-
-celix_status_t bundleContext_removeBundleListener(bundle_context_pt context, bundle_listener_pt listener) {
-	mock_c()->actualCall("bundleContext_removeBundleListener");
-	return mock_c()->returnValue().value.intValue;
-}
-
-
-celix_status_t bundleContext_getProperty(bundle_context_pt context, const char *name, const char** value) {
-	mock_c()->actualCall("bundleContext_getProperty")
-			->withPointerParameters("context", context)
-			->withStringParameters("name", name)
-			->withOutputParameter("value", value);
-	return mock_c()->returnValue().value.intValue;
-}
-
-long celix_bundleContext_registerService(bundle_context_t *ctx, void *svc, const char *serviceName, properties_t *properties) {
-	mock_c()->actualCall("celix_bundleContext_registerCService")
-			->withPointerParameters("ctx", ctx)
-			->withStringParameters("serviceName", serviceName)
-			->withPointerParameters("svc", svc)
-			->withPointerParameters("properties", properties);
-	return mock_c()->returnValue().value.longIntValue;
-}
-
-long celix_bundleContext_registerServiceWithOptions(celix_bundle_context_t *ctx, const celix_service_registration_options_t *opts) {
-	mock_c()->actualCall("celix_bundleContext_registerServiceWithOptions")
-			->withPointerParameters("ctx", ctx)
-			->withConstPointerParameters("opts", opts);
-	return mock_c()->returnValue().value.longIntValue;
-}
-
-void celix_bundleContext_unregisterService(bundle_context_t *ctx, long serviceId) {
-	mock_c()->actualCall("celix_bundleContext_unregisterService")
-			->withPointerParameters("ctx", ctx)
-			->withLongIntParameters("serviceId", serviceId);
-}
-
-bool celix_bundleContext_useServiceWithId(
-		bundle_context_t *ctx,
-		long serviceId,
-		const char *serviceName,
-		void *callbackHandle,
-		void (*use)(void *handle, void* svc)
-) {
-	mock_c()->actualCall("celix_bundleContext_registerServiceForLang")
-			->withPointerParameters("ctx", ctx)
-			->withLongIntParameters("serviceId", serviceId)
-			->withStringParameters("serviceName", serviceName)
-			->withPointerParameters("callbackHandle", callbackHandle)
-			->withPointerParameters("use", use);
-	return mock_c()->returnValue().value.boolValue;
-}
-
-dm_dependency_manager_t* celix_bundleContext_getDependencyManager(bundle_context_t *ctx) {
-	mock_c()->actualCall("celix_bundleContext_getDependencyManager");
-	return mock_c()->returnValue().value.pointerValue;
-}
-
-long celix_bundleContext_trackBundlesWithOptions(
-		bundle_context_t* ctx,
-		const celix_bundle_tracking_options_t *opts) {
-	mock_c()->actualCall("celix_bundleContext_trackBundlesWithOptions")
-			->withPointerParameters("ctx", ctx)
-			->withConstPointerParameters("opts", opts);
-	return mock_c()->returnValue().value.longIntValue;
-}
-
-long celix_bundleContext_trackBundles(
-		bundle_context_t* ctx,
-		void* callbackHandle,
-		void (*onStarted)(void* handle, const bundle_t *bundle),
-		void (*onStopped)(void *handle, const bundle_t *bundle)) {
-	mock_c()->actualCall("celix_bundleContext_trackBundles")
-			->withPointerParameters("ctx", ctx)
-			->withPointerParameters("callbackHandle", callbackHandle)
-			->withPointerParameters("onStarted", onStarted)
-			->withPointerParameters("onStopped", onStopped);
-	return mock_c()->returnValue().value.longIntValue;
-}
-
-
-void celix_bundleContext_useBundles(
-		bundle_context_t *ctx,
-		void *callbackHandle,
-		void (*use)(void *handle, const bundle_t *bundle)) {
-	mock_c()->actualCall("celix_bundleContext_useBundles")
-			->withPointerParameters("ctx", ctx)
-			->withPointerParameters("callbackHandle", callbackHandle)
-			->withPointerParameters("use", use);
-}
-
-
-void celix_bundleContext_useBundle(
-		bundle_context_t *ctx,
-		long bundleId,
-		void *callbackHandle,
-		void (*use)(void *handle, const bundle_t *bundle)) {
-	mock_c()->actualCall("celix_bundleContext_useBundle")
-			->withPointerParameters("ctx", ctx)
-			->withLongIntParameters("bundleId", bundleId)
-			->withPointerParameters("callbackHandle", callbackHandle)
-			->withPointerParameters("use", use);
-}
-
-void celix_bundleContext_stopTracker(bundle_context_t *ctx, long trackerId) {
-	mock_c()->actualCall("celix_bundleContext_stopTracker")
-			->withPointerParameters("ctx", ctx)
-			->withLongIntParameters("trackerId", trackerId);
-}
-
-long celix_bundleContext_installBundle(bundle_context_t *ctx, const char *bundleLoc, bool autoStart) {
-	mock_c()->actualCall("celix_bundleContext_installBundle")
-			->withPointerParameters("ctx", ctx)
-			->withStringParameters("bundleLoc", bundleLoc)
-			->withBoolParameters("autoStart", autoStart);
-	return mock_c()->returnValue().value.longIntValue;
-}
-
-bool celix_bundleContext_uninstallBundle(bundle_context_t *ctx, long bundleId) {
-	mock_c()->actualCall("celix_bundleContext_uninstallBundle")
-			->withPointerParameters("ctx", ctx)
-			->withLongIntParameters("bundleId", bundleId);
-	return mock_c()->returnValue().value.boolValue;
-}
-
-bool celix_bundleContext_useServiceWithOptions(
-		celix_bundle_context_t *ctx,
-		const celix_service_use_options_t *opts) {
-	mock_c()->actualCall("celix_bundleContext_useServiceWithOptions")
-			->withPointerParameters("ctx", ctx)
-			->withConstPointerParameters("opts", opts);
-	return mock_c()->returnValue().value.boolValue;
-}
-
-
-void celix_bundleContext_useServicesWithOptions(
-		celix_bundle_context_t *ctx,
-		const celix_service_use_options_t *opts) {
-	mock_c()->actualCall("celix_bundleContext_useServicesWithOptions")
-			->withPointerParameters("ctx", ctx)
-			->withConstPointerParameters("opts", opts);
-}
-
-long celix_bundleContext_registerServiceFactory(celix_bundle_context_t *ctx, celix_service_factory_t *factory, const char *serviceName, celix_properties_t *props) {
-	mock_c()->actualCall("celix_bundleContext_registerServiceFactory")
-			->withPointerParameters("ctx", ctx)
-			->withStringParameters("serviceName", serviceName)
-			->withPointerParameters("factory", factory)
-			->withPointerParameters("props", props);
-	return mock_c()->returnValue().value.longIntValue;
-}
-
-long celix_bundleContext_findService(celix_bundle_context_t *ctx, const char *serviceName) {
-	mock_c()->actualCall("celix_bundleContext_findService")
-			->withPointerParameters("ctx", ctx)
-			->withStringParameters("serviceName", serviceName);
-	return mock_c()->returnValue().value.longIntValue;
-}
-
-
-long celix_bundleContext_findServiceWithOptions(celix_bundle_context_t *ctx, const celix_service_filter_options_t *opts) {
-	mock_c()->actualCall("celix_bundleContext_findServiceWithOptions")
-			->withPointerParameters("ctx", ctx)
-			->withConstPointerParameters("opts", opts);
-	return mock_c()->returnValue().value.longIntValue;
-}
-
-
-celix_array_list_t* celix_bundleContext_findServices(celix_bundle_context_t *ctx, const char *serviceName) {
-	mock_c()->actualCall("celix_bundleContext_findServices")
-			->withPointerParameters("ctx", ctx)
-			->withStringParameters("serviceName", serviceName);
-	return mock_c()->returnValue().value.pointerValue;
-}
-
-celix_array_list_t* celix_bundleContext_findServicesWithOptions(celix_bundle_context_t *ctx, const celix_service_filter_options_t *opts) {
-	mock_c()->actualCall("celix_bundleContext_findServicesWithOptions")
-			->withPointerParameters("ctx", ctx)
-			->withConstPointerParameters("opts", opts);
-	return mock_c()->returnValue().value.pointerValue;
-}
\ No newline at end of file