Return-Path: X-Original-To: archive-asf-public-internal@cust-asf2.ponee.io Delivered-To: archive-asf-public-internal@cust-asf2.ponee.io Received: from cust-asf.ponee.io (cust-asf.ponee.io [163.172.22.183]) by cust-asf2.ponee.io (Postfix) with ESMTP id DC32B200D53 for ; Mon, 20 Nov 2017 21:33:03 +0100 (CET) Received: by cust-asf.ponee.io (Postfix) id DAC91160C1D; Mon, 20 Nov 2017 20:33:03 +0000 (UTC) Delivered-To: archive-asf-public@cust-asf.ponee.io Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by cust-asf.ponee.io (Postfix) with SMTP id 2F2EA160BE1 for ; Mon, 20 Nov 2017 21:33:01 +0100 (CET) Received: (qmail 60299 invoked by uid 500); 20 Nov 2017 20:33:00 -0000 Mailing-List: contact commits-help@celix.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: dev@celix.apache.org Delivered-To: mailing list commits@celix.apache.org Received: (qmail 59395 invoked by uid 99); 20 Nov 2017 20:32:59 -0000 Received: from git1-us-west.apache.org (HELO git1-us-west.apache.org) (140.211.11.23) by apache.org (qpsmtpd/0.29) with ESMTP; Mon, 20 Nov 2017 20:32:59 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id A580DF5F80; Mon, 20 Nov 2017 20:32:58 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: pnoltes@apache.org To: commits@celix.apache.org Date: Mon, 20 Nov 2017 20:33:16 -0000 Message-Id: <3884673c6a6c49a5a30b54814c85e0b9@git.apache.org> In-Reply-To: References: X-Mailer: ASF-Git Admin Mailer Subject: [19/46] celix git commit: CELIX-417: Initial refactoring for CMake usage archived-at: Mon, 20 Nov 2017 20:33:04 -0000 http://git-wip-us.apache.org/repos/asf/celix/blob/a1c30887/framework/public/include/bundle_activator.h ---------------------------------------------------------------------- diff --git a/framework/public/include/bundle_activator.h b/framework/public/include/bundle_activator.h deleted file mode 100644 index 1027351..0000000 --- a/framework/public/include/bundle_activator.h +++ /dev/null @@ -1,126 +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 BundleActivator BundleActivator - * @ingroup framework - * @{ - * \brief Customizes the starting and stopping of a bundle. - * \details \ref BundleActivator is a header that must be implemented by every - * bundle. The Framework creates/starts/stops/destroys activator instances using the - * functions described in this header. If the bundleActivator_start() - * function executes successfully, it is guaranteed that the same instance's - * bundleActivator_stop() function will be called when the bundle is - * to be stopped. The same applies to the bundleActivator_create() and - * bundleActivator_destroy() functions. - * The Framework must not concurrently call the activator functions. - * \author Apache Celix Project Team - * \date March 18, 2010 - * \copyright Apache License, Version 2.0 - */ -#ifndef BUNDLE_ACTIVATOR_H_ -#define BUNDLE_ACTIVATOR_H_ - -#include "bundle_context.h" -#include "framework_exports.h" - -#ifdef __cplusplus -extern "C" { -#endif - -/** - * Called when this bundle is started so the bundle can create an instance for its activator. - * The framework does not assume any type for the activator instance, this is implementation specific. - * The activator instance is handle as a void pointer by the framework, the implementation must cast it to the - * implementation specific type. - * - * @param context The execution context of the bundle being started. - * @param[out] userData A pointer to the specific activator instance used by this bundle. - * - * @return Status code indication failure or success: - * - CELIX_SUCCESS when no errors are encountered. - * - Any other status code will mark the bundle as stopped and the framework will remove this - * bundle's listeners, unregister all services, and release all services used by this bundle. - */ -ACTIVATOR_EXPORT celix_status_t bundleActivator_create(bundle_context_pt context_ptr, void **userData); - -/** - * Called when this bundle is started so the Framework can perform the bundle-specific activities necessary - * to start this bundle. This method can be used to register services or to allocate any resources that this - * bundle needs. - * - *

- * This method must complete and return to its caller in a timely manner. - * - * @param userData The activator instance to be used. - * @param context The execution context of the bundle being started. - * - * @return Status code indication failure or success: - * - CELIX_SUCCESS when no errors are encountered. - * - Any other status code will mark the bundle as stopped and the framework will remove this - * bundle's listeners, unregister all services, and release all services used by this bundle. - */ -ACTIVATOR_EXPORT celix_status_t bundleActivator_start(void *userData, bundle_context_pt context); - -/** - * Called when this bundle is stopped so the Framework can perform the bundle-specific activities necessary - * to stop the bundle. In general, this method should undo the work that the bundleActivator_start() - * function started. There should be no active threads that were started by this bundle when this bundle returns. - * A stopped bundle must not call any Framework objects. - * - *

- * This method must complete and return to its caller in a timely manner. - * - * @param userData The activator instance to be used. - * @param context The execution context of the bundle being stopped. - * - * @return Status code indication failure or success: - * - CELIX_SUCCESS when no errors are encountered. - * - Any other status code will mark the bundle as stopped and the framework will remove this - * bundle's listeners, unregister all services, and release all services used by this bundle. - */ -ACTIVATOR_EXPORT celix_status_t bundleActivator_stop(void *userData, bundle_context_pt context); - -/** - * Called when this bundle is stopped so the bundle can destroy the instance of its activator. In general, this - * method should undo the work that the bundleActivator_create() function initialized. - * - *

- * This method must complete and return to its caller in a timely manner. - * - * @param userData The activator instance to be used. - * @param context The execution context of the bundle being stopped. - * - * @return Status code indication failure or success: - * - CELIX_SUCCESS when no errors are encountered. - * - Any other status code will mark the bundle as stopped and the framework will remove this - * bundle's listeners, unregister all services, and release all services used by this bundle. - */ -ACTIVATOR_EXPORT celix_status_t -bundleActivator_destroy(void *userData, bundle_context_pt __attribute__((unused)) __attribute__((unused)) context); - -#ifdef __cplusplus -} -#endif - -#endif /* BUNDLE_ACTIVATOR_H_ */ - -/** - * @} - */ http://git-wip-us.apache.org/repos/asf/celix/blob/a1c30887/framework/public/include/bundle_archive.h ---------------------------------------------------------------------- diff --git a/framework/public/include/bundle_archive.h b/framework/public/include/bundle_archive.h deleted file mode 100644 index ff3cf16..0000000 --- a/framework/public/include/bundle_archive.h +++ /dev/null @@ -1,93 +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.h - * - * \date Aug 8, 2010 - * \author Apache Celix Project Team - * \copyright Apache License, Version 2.0 - */ - -#ifndef BUNDLE_ARCHIVE_H_ -#define BUNDLE_ARCHIVE_H_ - -#include - -#include "bundle_revision.h" -#include "bundle_state.h" -#include "celix_errno.h" -#include "celixbool.h" -#include "framework_exports.h" -#include "celix_log.h" - -#ifdef __cplusplus -extern "C" { -#endif - -typedef struct bundleArchive *bundle_archive_pt; - -celix_status_t bundleArchive_create(const char *archiveRoot, long id, const char *location, const char *inputFile, - bundle_archive_pt *bundle_archive); - -celix_status_t bundleArchive_createSystemBundleArchive(bundle_archive_pt *bundle_archive); - -celix_status_t bundleArchive_recreate(const char *archiveRoot, bundle_archive_pt *bundle_archive); - -celix_status_t bundleArchive_destroy(bundle_archive_pt archive); - -FRAMEWORK_EXPORT celix_status_t bundleArchive_getId(bundle_archive_pt archive, long *id); - -FRAMEWORK_EXPORT celix_status_t bundleArchive_getLocation(bundle_archive_pt archive, const char **location); - -FRAMEWORK_EXPORT celix_status_t bundleArchive_getArchiveRoot(bundle_archive_pt archive, const char **archiveRoot); - -FRAMEWORK_EXPORT celix_status_t -bundleArchive_revise(bundle_archive_pt archive, const char *location, const char *inputFile); - -FRAMEWORK_EXPORT celix_status_t bundleArchive_rollbackRevise(bundle_archive_pt archive, bool *rolledback); - -FRAMEWORK_EXPORT celix_status_t -bundleArchive_getRevision(bundle_archive_pt archive, long revNr, bundle_revision_pt *revision); - -FRAMEWORK_EXPORT celix_status_t -bundleArchive_getCurrentRevision(bundle_archive_pt archive, bundle_revision_pt *revision); - -FRAMEWORK_EXPORT celix_status_t bundleArchive_getCurrentRevisionNumber(bundle_archive_pt archive, long *revisionNumber); - -FRAMEWORK_EXPORT celix_status_t bundleArchive_getRefreshCount(bundle_archive_pt archive, long *refreshCount); - -FRAMEWORK_EXPORT celix_status_t bundleArchive_setRefreshCount(bundle_archive_pt archive); - -FRAMEWORK_EXPORT celix_status_t bundleArchive_close(bundle_archive_pt archive); - -FRAMEWORK_EXPORT celix_status_t bundleArchive_closeAndDelete(bundle_archive_pt archive); - -FRAMEWORK_EXPORT celix_status_t bundleArchive_setLastModified(bundle_archive_pt archive, time_t lastModifiedTime); - -FRAMEWORK_EXPORT celix_status_t bundleArchive_getLastModified(bundle_archive_pt archive, time_t *lastModified); - -FRAMEWORK_EXPORT celix_status_t bundleArchive_setPersistentState(bundle_archive_pt archive, bundle_state_e state); - -FRAMEWORK_EXPORT celix_status_t bundleArchive_getPersistentState(bundle_archive_pt archive, bundle_state_e *state); - -#ifdef __cplusplus -} -#endif - -#endif /* BUNDLE_ARCHIVE_H_ */ http://git-wip-us.apache.org/repos/asf/celix/blob/a1c30887/framework/public/include/bundle_context.h ---------------------------------------------------------------------- diff --git a/framework/public/include/bundle_context.h b/framework/public/include/bundle_context.h deleted file mode 100644 index c674e9c..0000000 --- a/framework/public/include/bundle_context.h +++ /dev/null @@ -1,159 +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.h - * - * \date Mar 26, 2010 - * \author Apache Celix Project Team - * \copyright Apache License, Version 2.0 - */ - -#ifndef BUNDLE_CONTEXT_H_ -#define BUNDLE_CONTEXT_H_ - -/** - * A bundle's execution context within the Framework. The context is used to - * grant access to other methods so that this bundle can interact with the - * Framework. - */ -typedef struct bundleContext *bundle_context_pt; -typedef struct bundleContext bundle_context_t; - - -#include "service_factory.h" -#include "service_listener.h" -#include "bundle_listener.h" -#include "framework_listener.h" -#include "properties.h" -#include "array_list.h" - -#ifdef __cplusplus -extern "C" { -#endif - -celix_status_t -bundleContext_create(framework_pt framework, framework_logger_pt, bundle_pt bundle, bundle_context_pt *bundle_context); - -celix_status_t bundleContext_destroy(bundle_context_pt context); - -FRAMEWORK_EXPORT celix_status_t bundleContext_getBundle(bundle_context_pt context, bundle_pt *bundle); - -FRAMEWORK_EXPORT celix_status_t bundleContext_getFramework(bundle_context_pt context, framework_pt *framework); - -FRAMEWORK_EXPORT celix_status_t -bundleContext_installBundle(bundle_context_pt context, const char *location, bundle_pt *bundle); - -FRAMEWORK_EXPORT celix_status_t -bundleContext_installBundle2(bundle_context_pt context, const char *location, const char *inputFile, bundle_pt *bundle); - -FRAMEWORK_EXPORT celix_status_t -bundleContext_registerService(bundle_context_pt context, const char *serviceName, const void *svcObj, - properties_pt properties, service_registration_pt *service_registration); - -FRAMEWORK_EXPORT celix_status_t -bundleContext_registerServiceFactory(bundle_context_pt context, const char *serviceName, service_factory_pt factory, - properties_pt properties, service_registration_pt *service_registration); - -/** - * Get a service reference for the bundle context. When the service reference is no longer needed use bundleContext_ungetServiceReference. - * ServiceReference are coupled to a bundle context. Do not share service reference between bundles. Exchange the service.id instead. - * - * @param context The bundle context - * @param serviceName The name of the service (objectClass) to get - * @param service_reference _output_ The found service reference, or NULL when no service is found. - * @return CELIX_SUCCESS on success - */ -FRAMEWORK_EXPORT celix_status_t bundleContext_getServiceReference(bundle_context_pt context, const char *serviceName, - service_reference_pt *service_reference); - -/** Same as bundleContext_getServiceReference, but than for a optional serviceName combined with a optional filter. - * The resulting array_list should be destroyed by the caller. For all service references return a unget should be called. - * - * @param context the bundle context - * @param serviceName the serviceName, can be NULL - * @param filter the filter, can be NULL. If present will be combined (and) with the serviceName - * @param service_references _output_ a array list, can be size 0. - * @return CELIX_SUCCESS on success - */ -FRAMEWORK_EXPORT celix_status_t -bundleContext_getServiceReferences(bundle_context_pt context, const char *serviceName, const char *filter, - array_list_pt *service_references); - -/** - * Retains (increases the ref count) the provided service reference. Can be used to retain a service reference. - * Note that this is a deviation from the OSGi spec, due to the fact that C has no garbage collect. - * - * @param context the bundle context - * @param reference the service reference to retain - * @return CELIX_SUCCES on success - */ -FRAMEWORK_EXPORT celix_status_t -bundleContext_retainServiceReference(bundle_context_pt context, service_reference_pt reference); - -/** - * Ungets the service references. If the ref counter of the service refernce goes to 0, the reference will be destroyed. - * This is coupled with the bundleContext_getServiceReference(s) and bundleContext_retainServiceReferenc. - * Note: That this is a deviation from the OSGi standard, due to the fact that C has no garbage collect. - * - * @param context The bundle context. - * @param reference the service reference to unget - * @return CELIX_SUCCESS on success. - */ -FRAMEWORK_EXPORT celix_status_t -bundleContext_ungetServiceReference(bundle_context_pt context, service_reference_pt reference); - -FRAMEWORK_EXPORT celix_status_t -bundleContext_getService(bundle_context_pt context, service_reference_pt reference, void **service_instance); - -FRAMEWORK_EXPORT celix_status_t -bundleContext_ungetService(bundle_context_pt context, service_reference_pt reference, bool *result); - -FRAMEWORK_EXPORT celix_status_t bundleContext_getBundles(bundle_context_pt context, array_list_pt *bundles); - -FRAMEWORK_EXPORT celix_status_t bundleContext_getBundleById(bundle_context_pt context, long id, bundle_pt *bundle); - -FRAMEWORK_EXPORT celix_status_t -bundleContext_addServiceListener(bundle_context_pt context, service_listener_pt listener, const char *filter); - -FRAMEWORK_EXPORT celix_status_t -bundleContext_removeServiceListener(bundle_context_pt context, service_listener_pt listener); - -FRAMEWORK_EXPORT celix_status_t bundleContext_addBundleListener(bundle_context_pt context, bundle_listener_pt listener); - -FRAMEWORK_EXPORT celix_status_t -bundleContext_removeBundleListener(bundle_context_pt context, bundle_listener_pt listener); - -FRAMEWORK_EXPORT celix_status_t -bundleContext_addFrameworkListener(bundle_context_pt context, framework_listener_pt listener); - -FRAMEWORK_EXPORT celix_status_t -bundleContext_removeFrameworkListener(bundle_context_pt context, framework_listener_pt listener); - -FRAMEWORK_EXPORT celix_status_t -bundleContext_getProperty(bundle_context_pt context, const char *name, const char **value); - -FRAMEWORK_EXPORT celix_status_t -bundleContext_getPropertyWithDefault(bundle_context_pt context, const char *name, const char *defaultValue, - const char **value); - -#ifdef __cplusplus -} -#endif - -#endif /* BUNDLE_CONTEXT_H_ */ http://git-wip-us.apache.org/repos/asf/celix/blob/a1c30887/framework/public/include/bundle_event.h ---------------------------------------------------------------------- diff --git a/framework/public/include/bundle_event.h b/framework/public/include/bundle_event.h deleted file mode 100644 index c4fc927..0000000 --- a/framework/public/include/bundle_event.h +++ /dev/null @@ -1,63 +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_event.h - * - * \date Jun 28, 2012 - * \author Apache Celix Project Team - * \copyright Apache License, Version 2.0 - */ - -#ifndef BUNDLE_EVENT_H_ -#define BUNDLE_EVENT_H_ - -#ifdef __cplusplus -extern "C" { -#endif - -enum bundle_event_type { - OSGI_FRAMEWORK_BUNDLE_EVENT_INSTALLED = 0x00000001, - OSGI_FRAMEWORK_BUNDLE_EVENT_STARTED = 0x00000002, - OSGI_FRAMEWORK_BUNDLE_EVENT_STOPPED = 0x00000004, - OSGI_FRAMEWORK_BUNDLE_EVENT_UPDATED = 0x00000008, - OSGI_FRAMEWORK_BUNDLE_EVENT_UNINSTALLED = 0x00000010, - OSGI_FRAMEWORK_BUNDLE_EVENT_RESOLVED = 0x00000020, - OSGI_FRAMEWORK_BUNDLE_EVENT_UNRESOLVED = 0x00000040, - OSGI_FRAMEWORK_BUNDLE_EVENT_STARTING = 0x00000080, - OSGI_FRAMEWORK_BUNDLE_EVENT_STOPPING = 0x00000100, - OSGI_FRAMEWORK_BUNDLE_EVENT_LAZY_ACTIVATION = 0x00000200, -}; - -typedef enum bundle_event_type bundle_event_type_e; -typedef struct bundle_event *bundle_event_pt; - -#include "service_reference.h" -#include "bundle.h" - -struct bundle_event { - long bundleId; - char *bundleSymbolicName; - bundle_event_type_e type; -}; - -#ifdef __cplusplus -} -#endif - -#endif /* BUNDLE_EVENT_H_ */ http://git-wip-us.apache.org/repos/asf/celix/blob/a1c30887/framework/public/include/bundle_listener.h ---------------------------------------------------------------------- diff --git a/framework/public/include/bundle_listener.h b/framework/public/include/bundle_listener.h deleted file mode 100644 index a152393..0000000 --- a/framework/public/include/bundle_listener.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. - */ -/** - * - * @defgroup BundleListener Bundle Listener - * @ingroup framework - * @{ - * - * \author Apache Celix Project Team - * \date June 28, 2012 - * \copyright Apache License, Version 2.0 - */ -#ifndef BUNDLE_LISTENER_H_ -#define BUNDLE_LISTENER_H_ - -typedef struct bundle_listener *bundle_listener_pt; - -#include "celix_errno.h" -#include "bundle_event.h" - -#ifdef __cplusplus -extern "C" { -#endif - - -struct bundle_listener { - void *handle; - - celix_status_t (*bundleChanged)(void *listener, bundle_event_pt event); -}; - -#ifdef __cplusplus -} -#endif - - -#endif /* service_listener_t_H_ */ - -/** - * @} - */ http://git-wip-us.apache.org/repos/asf/celix/blob/a1c30887/framework/public/include/bundle_revision.h ---------------------------------------------------------------------- diff --git a/framework/public/include/bundle_revision.h b/framework/public/include/bundle_revision.h deleted file mode 100644 index 9533eb6..0000000 --- a/framework/public/include/bundle_revision.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. - */ -/** - * - * @defgroup BundleRevision Bundle Revision - * @ingroup framework - * @{ - * - * \author Apache Celix Project Team - * \date April 12, 2011 - * \copyright Apache License, Version 2.0 - */ -#ifndef BUNDLE_REVISION_H_ -#define BUNDLE_REVISION_H_ - -#include - -#include "celix_errno.h" -#include "manifest.h" -#include "celix_log.h" -#include "array_list.h" - -#ifdef __cplusplus -extern "C" { -#endif - -/** - * Typedef for bundle_revision_pt. - * - * A bundle revision represents the content of a bundle. A revision is associated with a bundle archive. - * An archive can have multiple revisions, each update of a bundle results in a new one. - * - * In a revision the content of a bundle (ZIP file) is extracted to a specified location inside the archive. - */ -typedef struct bundleRevision *bundle_revision_pt; - -/** - * Creates a new revision for the given inputFile or location. - * The location parameter is used to identify the bundle, in case of an update or download, the inputFile - * parameter can be used to point to the actual data. In the OSGi specification this is the inputstream. - * - * @param pool The pool on which this revision has to be allocated. - * @param root The root for this revision in which the bundle is extracted and state is stored. - * @param location The location associated with the revision - * @param revisionNr The number of the revision - * @param inputFile The (optional) location of the file to use as input for this revision - * @param[out] bundle_revision The output parameter for the created revision. - * - * @return Status code indication failure or success: - * - CELIX_SUCCESS when no errors are encountered. - * - CELIX_ENOMEM If allocating memory for bundle_revision failed. - */ -celix_status_t bundleRevision_create(const char *root, const char *location, long revisionNr, const char *inputFile, - bundle_revision_pt *bundle_revision); - -celix_status_t bundleRevision_destroy(bundle_revision_pt revision); - -/** - * Retrieves the revision number of the given revision. - * - * @param revision The revision to get the number for. - * @param[out] revisionNr The revision number. - * - * @return Status code indication failure or success: - * - CELIX_SUCCESS when no errors are encountered. - * - CELIX_ILLEGAL_ARGUMENT If revision is illegal. - */ -celix_status_t bundleRevision_getNumber(bundle_revision_pt revision, long *revisionNr); - -/** - * Retrieves the location of the given revision. - * - * @param revision The revision to get the location for. - * @param[out] location The location. - * - * @return Status code indication failure or success: - * - CELIX_SUCCESS when no errors are encountered. - * - CELIX_ILLEGAL_ARGUMENT If revision is illegal. - */ -celix_status_t bundleRevision_getLocation(bundle_revision_pt revision, const char **location); - -/** - * Retrieves the root of the given revision. - * - * @param revision The revision to get the location for. - * @param[out] root The root. - * - * @return Status code indication failure or success: - * - CELIX_SUCCESS when no errors are encountered. - * - CELIX_ILLEGAL_ARGUMENT If revision is illegal. - */ -celix_status_t bundleRevision_getRoot(bundle_revision_pt revision, const char **root); - -/** - * Retrieves the manifest of the given revision. - * - * @param revision The revision to get the manifest for. - * @param[out] manifest The manifest. - * - * @return Status code indication failure or success: - * - CELIX_SUCCESS when no errors are encountered. - * - CELIX_ILLEGAL_ARGUMENT If revision is illegal. - */ -celix_status_t bundleRevision_getManifest(bundle_revision_pt revision, manifest_pt *manifest); - -/** - * Retrieves the handles of the installed libraries for this revision. - * - * @param revision The revision to get the manifest for. - * @param[out] handles array_list_pt containing the handles. - * - * @return Status code indication failure or success: - * - CELIX_SUCCESS when no errors are encountered. - * - CELIX_ILLEGAL_ARGUMENT If revision is illegal. - */ -celix_status_t bundleRevision_getHandles(bundle_revision_pt revision, array_list_pt *handles); - -#ifdef __cplusplus -} -#endif - -#endif /* BUNDLE_REVISION_H_ */ - -/** - * @} - */ http://git-wip-us.apache.org/repos/asf/celix/blob/a1c30887/framework/public/include/bundle_state.h ---------------------------------------------------------------------- diff --git a/framework/public/include/bundle_state.h b/framework/public/include/bundle_state.h deleted file mode 100644 index 8d451e4..0000000 --- a/framework/public/include/bundle_state.h +++ /dev/null @@ -1,49 +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_state.h - * - * \date Sep 27, 2010 - * \author Apache Celix Project Team - * \copyright Apache License, Version 2.0 - */ - -#ifndef BUNDLE_STATE_H_ -#define BUNDLE_STATE_H_ - -#ifdef __cplusplus -extern "C" { -#endif - -enum bundleState { - OSGI_FRAMEWORK_BUNDLE_UNKNOWN = 0x00000000, - OSGI_FRAMEWORK_BUNDLE_UNINSTALLED = 0x00000001, - OSGI_FRAMEWORK_BUNDLE_INSTALLED = 0x00000002, - OSGI_FRAMEWORK_BUNDLE_RESOLVED = 0x00000004, - OSGI_FRAMEWORK_BUNDLE_STARTING = 0x00000008, - OSGI_FRAMEWORK_BUNDLE_STOPPING = 0x00000010, - OSGI_FRAMEWORK_BUNDLE_ACTIVE = 0x00000020, -}; - -typedef enum bundleState bundle_state_e; -#ifdef __cplusplus -} -#endif - -#endif /* BUNDLE_STATE_H_ */ http://git-wip-us.apache.org/repos/asf/celix/blob/a1c30887/framework/public/include/capability.h ---------------------------------------------------------------------- diff --git a/framework/public/include/capability.h b/framework/public/include/capability.h deleted file mode 100644 index b35d016..0000000 --- a/framework/public/include/capability.h +++ /dev/null @@ -1,54 +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. - */ -/* - * capability.h - * - * \date Jul 12, 2010 - * \author Apache Celix Project Team - * \copyright Apache License, Version 2.0 - */ - -#ifndef CAPABILITY_H_ -#define CAPABILITY_H_ - -typedef struct capability *capability_pt; - -#include "hash_map.h" -#include "module.h" - -#ifdef __cplusplus -extern "C" { -#endif - -celix_status_t -capability_create(module_pt module, hash_map_pt directives, hash_map_pt attributes, capability_pt *capability); - -celix_status_t capability_destroy(capability_pt capability); - -celix_status_t capability_getServiceName(capability_pt capability, const char **serviceName); - -celix_status_t capability_getVersion(capability_pt capability, version_pt *version); - -celix_status_t capability_getModule(capability_pt capability, module_pt *module); - -#ifdef __cplusplus -} -#endif - -#endif /* CAPABILITY_H_ */ http://git-wip-us.apache.org/repos/asf/celix/blob/a1c30887/framework/public/include/celix_launcher.h ---------------------------------------------------------------------- diff --git a/framework/public/include/celix_launcher.h b/framework/public/include/celix_launcher.h deleted file mode 100644 index 0d819c9..0000000 --- a/framework/public/include/celix_launcher.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. - */ -/* - * celix_launcher.h - * - * \date Jul 30, 2015 - * \author Apache Celix Project Team - * \copyright Apache License, Version 2.0 - */ - -#ifndef CELIX_LAUNCHER_H -#define CELIX_LAUNCHER_H - -#include -#include "framework.h" - -#ifdef __cplusplus -extern "C" { -#endif - -int celixLauncher_launchWithArgs(int argc, char *argv[]); - -int celixLauncher_launch(const char *configFile, framework_pt *framework); - -int celixLauncher_launchWithStream(FILE *config, framework_pt *framework); - -int celixLauncher_launchWithProperties(properties_pt config, framework_pt *framework); - -void celixLauncher_stop(framework_pt framework); - -void celixLauncher_destroy(framework_pt framework); - -void celixLauncher_waitForShutdown(framework_pt framework); - -#ifdef __cplusplus -} -#endif - -#endif //CELIX_LAUNCHER_H http://git-wip-us.apache.org/repos/asf/celix/blob/a1c30887/framework/public/include/celix_log.h ---------------------------------------------------------------------- diff --git a/framework/public/include/celix_log.h b/framework/public/include/celix_log.h deleted file mode 100644 index 08d096c..0000000 --- a/framework/public/include/celix_log.h +++ /dev/null @@ -1,85 +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. - */ -/* - * celix_log.h - * - * \date Jan 12, 2012 - * \author Apache Celix Project Team - * \copyright Apache License, Version 2.0 - */ - -#ifndef CELIX_LOG_H_ -#define CELIX_LOG_H_ - -#include - -#include "celix_errno.h" -#include "framework_exports.h" - -#ifdef __cplusplus -extern "C" { -#endif - -enum framework_log_level { - OSGI_FRAMEWORK_LOG_ERROR = 0x00000001, - OSGI_FRAMEWORK_LOG_WARNING = 0x00000002, - OSGI_FRAMEWORK_LOG_INFO = 0x00000003, - OSGI_FRAMEWORK_LOG_DEBUG = 0x00000004, -}; - -typedef enum framework_log_level framework_log_level_t; - -typedef struct framework_logger *framework_logger_pt; - -extern framework_logger_pt logger; - -typedef celix_status_t (*framework_log_function_pt)(framework_log_level_t level, const char *func, const char *file, - int line, const char *msg); - -struct framework_logger { - framework_log_function_pt logFunction; -}; - -#define fw_log(logger, level, fmsg, args...) framework_log(logger, level, __func__, __FILE__, __LINE__, fmsg, ## args) -#define fw_logCode(logger, level, code, fmsg, args...) framework_logCode(logger, level, __func__, __FILE__, __LINE__, code, fmsg, ## args) -#define framework_logIfError(logger, status, error, fmsg, args...) \ - if (status != CELIX_SUCCESS) { \ - if (error != NULL) { \ - fw_logCode(logger, OSGI_FRAMEWORK_LOG_ERROR, status, #fmsg";\n Cause: %s", ## args, error); \ - } else { \ - fw_logCode(logger, OSGI_FRAMEWORK_LOG_ERROR, status, #fmsg, ## args); \ - } \ - } - -FRAMEWORK_EXPORT celix_status_t -frameworkLogger_log(framework_log_level_t level, const char *func, const char *file, int line, const char *fmsg); - -FRAMEWORK_EXPORT void -framework_log(framework_logger_pt logger, framework_log_level_t level, const char *func, const char *file, int line, - const char *fmsg, ...); - -FRAMEWORK_EXPORT void -framework_logCode(framework_logger_pt logger, framework_log_level_t level, const char *func, const char *file, int line, - celix_status_t code, const char *fmsg, ...); - -#ifdef __cplusplus -} -#endif - -#endif /* CELIX_LOG_H_ */ http://git-wip-us.apache.org/repos/asf/celix/blob/a1c30887/framework/public/include/constants.h ---------------------------------------------------------------------- diff --git a/framework/public/include/constants.h b/framework/public/include/constants.h deleted file mode 100644 index 5a01016..0000000 --- a/framework/public/include/constants.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. - */ -/* - * constants.h - * - * \date Apr 29, 2010 - * \author Apache Celix Project Team - * \copyright Apache License, Version 2.0 - */ - -#ifndef CONSTANTS_H_ -#define CONSTANTS_H_ - -#ifdef __cplusplus -extern "C" { -#endif - -static const char *const OSGI_FRAMEWORK_OBJECTCLASS = "objectClass"; -static const char *const OSGI_FRAMEWORK_SERVICE_ID = "service.id"; -static const char *const OSGI_FRAMEWORK_SERVICE_PID = "service.pid"; -static const char *const OSGI_FRAMEWORK_SERVICE_RANKING = "service.ranking"; - -static const char *const CELIX_FRAMEWORK_SERVICE_VERSION = "service.version"; -static const char *const CELIX_FRAMEWORK_SERVICE_LANGUAGE = "service.lang"; -static const char *const CELIX_FRAMEWORK_SERVICE_C_LANGUAGE = "C"; -static const char *const CELIX_FRAMEWORK_SERVICE_CXX_LANGUAGE = "C++"; -static const char *const CELIX_FRAMEWORK_SERVICE_SHARED_LANGUAGE = "shared"; //e.g. marker services - -static const char *const OSGI_FRAMEWORK_BUNDLE_ACTIVATOR = "Bundle-Activator"; -static const char *const OSGI_FRAMEWORK_BUNDLE_ACTIVATOR_CREATE = "bundleActivator_create"; -static const char *const OSGI_FRAMEWORK_BUNDLE_ACTIVATOR_START = "bundleActivator_start"; -static const char *const OSGI_FRAMEWORK_BUNDLE_ACTIVATOR_STOP = "bundleActivator_stop"; -static const char *const OSGI_FRAMEWORK_BUNDLE_ACTIVATOR_DESTROY = "bundleActivator_destroy"; - -static const char *const OSGI_FRAMEWORK_BUNDLE_SYMBOLICNAME = "Bundle-SymbolicName"; -static const char *const OSGI_FRAMEWORK_BUNDLE_VERSION = "Bundle-Version"; -static const char *const OSGI_FRAMEWORK_PRIVATE_LIBRARY = "Private-Library"; -static const char *const OSGI_FRAMEWORK_EXPORT_LIBRARY = "Export-Library"; -static const char *const OSGI_FRAMEWORK_IMPORT_LIBRARY = "Import-Library"; - - -static const char *const OSGI_FRAMEWORK_FRAMEWORK_STORAGE = "org.osgi.framework.storage"; -static const char *const OSGI_FRAMEWORK_FRAMEWORK_STORAGE_CLEAN = "org.osgi.framework.storage.clean"; -static const char *const OSGI_FRAMEWORK_FRAMEWORK_STORAGE_CLEAN_ONFIRSTINIT = "onFirstInit"; -static const char *const OSGI_FRAMEWORK_FRAMEWORK_UUID = "org.osgi.framework.uuid"; - -#ifdef __cplusplus -} -#endif - -#endif /* CONSTANTS_H_ */ http://git-wip-us.apache.org/repos/asf/celix/blob/a1c30887/framework/public/include/filter.h ---------------------------------------------------------------------- diff --git a/framework/public/include/filter.h b/framework/public/include/filter.h deleted file mode 100644 index 687de2a..0000000 --- a/framework/public/include/filter.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. - */ -/* - * filter.h - * - * \date Apr 28, 2010 - * \author Apache Celix Project Team - * \copyright Apache License, Version 2.0 - */ - -#ifndef FILTER_H_ -#define FILTER_H_ - -#include "celix_errno.h" -#include "properties.h" -#include "celixbool.h" -#include "framework_exports.h" - -#ifdef __cplusplus -extern "C" { -#endif - -typedef struct filter *filter_pt; - -FRAMEWORK_EXPORT filter_pt filter_create(const char *filterString); - -FRAMEWORK_EXPORT void filter_destroy(filter_pt filter); - -FRAMEWORK_EXPORT celix_status_t filter_match(filter_pt filter, properties_pt properties, bool *result); - -FRAMEWORK_EXPORT celix_status_t filter_match_filter(filter_pt src, filter_pt dest, bool *result); - -FRAMEWORK_EXPORT celix_status_t filter_getString(filter_pt filter, const char **filterStr); - -#ifdef __cplusplus -} -#endif - -#endif /* FILTER_H_ */ http://git-wip-us.apache.org/repos/asf/celix/blob/a1c30887/framework/public/include/framework.h ---------------------------------------------------------------------- diff --git a/framework/public/include/framework.h b/framework/public/include/framework.h deleted file mode 100644 index ec2306f..0000000 --- a/framework/public/include/framework.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. - */ -/* - * framework.h - * - * \date Mar 23, 2010 - * \author Apache Celix Project Team - * \copyright Apache License, Version 2.0 - */ - -#ifndef FRAMEWORK_H_ -#define FRAMEWORK_H_ - -typedef struct activator * activator_pt; -typedef struct framework * framework_pt; - -#include "celix_errno.h" -#include "framework_exports.h" -#include "bundle.h" -#include "properties.h" - -#ifdef __cplusplus -extern "C" { -#endif - -// #TODO: Move to FrameworkFactory according the OSGi Spec -FRAMEWORK_EXPORT celix_status_t framework_create(framework_pt *framework, properties_pt config); - -FRAMEWORK_EXPORT celix_status_t framework_destroy(framework_pt framework); - -FRAMEWORK_EXPORT celix_status_t fw_init(framework_pt framework); - -FRAMEWORK_EXPORT celix_status_t framework_waitForStop(framework_pt framework); - -FRAMEWORK_EXPORT celix_status_t framework_getFrameworkBundle(framework_pt framework, bundle_pt *bundle); - -#ifdef __cplusplus -} -#endif - -#endif /* FRAMEWORK_H_ */ http://git-wip-us.apache.org/repos/asf/celix/blob/a1c30887/framework/public/include/framework_event.h ---------------------------------------------------------------------- diff --git a/framework/public/include/framework_event.h b/framework/public/include/framework_event.h deleted file mode 100644 index d48e64c..0000000 --- a/framework/public/include/framework_event.h +++ /dev/null @@ -1,71 +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. - */ -/* - * framework_event.h - * - * \date Oct 8, 2013 - * \author Apache Celix Project Team - * \copyright Apache License, Version 2.0 - */ - -#ifndef FRAMEWORK_EVENT_H_ -#define FRAMEWORK_EVENT_H_ - -#ifdef __cplusplus -extern "C" { -#endif - -enum framework_event_type { - OSGI_FRAMEWORK_EVENT_STARTED = 0x00000001, - OSGI_FRAMEWORK_EVENT_ERROR = 0x00000002, - OSGI_FRAMEWORK_EVENT_PACKAGES_REFRESHED = 0x00000004, - OSGI_FRAMEWORK_EVENT_STARTLEVEL_CHANGED = 0x00000008, - OSGI_FRAMEWORK_EVENT_WARNING = 0x00000010, - OSGI_FRAMEWORK_EVENT_INFO = 0x00000020, - OSGI_FRAMEWORK_EVENT_STOPPED = 0x00000040, - OSGI_FRAMEWORK_EVENT_STOPPED_UPDATE = 0x00000080, - OSGI_FRAMEWORK_EVENT_STOPPED_BOOTCLASSPATH_MODIFIED = 0x00000100, - OSGI_FRAMEWORK_EVENT_WAIT_TIMEDOUT = 0x00000200, -}; - -typedef enum framework_event_type framework_event_type_e; -typedef struct framework_event *framework_event_pt; -#ifdef __cplusplus -} -#endif - -#include "service_reference.h" -#include "bundle.h" - -#ifdef __cplusplus -extern "C" { -#endif - -struct framework_event { - long bundleId; - char *bundleSymbolicName; - framework_event_type_e type; - celix_status_t errorCode; - char *error; -}; -#ifdef __cplusplus -} -#endif - -#endif /* FRAMEWORK_EVENT_H_ */ http://git-wip-us.apache.org/repos/asf/celix/blob/a1c30887/framework/public/include/framework_exports.h ---------------------------------------------------------------------- diff --git a/framework/public/include/framework_exports.h b/framework/public/include/framework_exports.h deleted file mode 100644 index 50d7f6e..0000000 --- a/framework/public/include/framework_exports.h +++ /dev/null @@ -1,65 +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. - */ -/* - * exports.h - */ - -#ifndef FRAMEWORK_EXPORTS_H_ -#define FRAMEWORK_EXPORTS_H_ - -/* Cmake will define celix_framework_EXPORTS on Windows when it -configures to build a shared library. If you are going to use -another build system on windows or create the visual studio -projects by hand you need to define celix_framework_EXPORTS when -building a DLL on windows. -*/ -// We are using the Visual Studio Compiler and building Shared libraries - -#if defined _WIN32 || defined __CYGWIN__ - #ifdef celix_framework_EXPORTS - #ifdef __GNUC__ - #define FRAMEWORK_EXPORT __attribute__ ((dllexport)) - #define ACTIVATOR_EXPORT __attribute__ ((dllexport)) - #else - #define ACTIVATOR_EXPORT __declspec(dllexport) - #define FRAMEWORK_EXPORT __declspec(dllexport) // Note: actually gcc seems to also supports this syntax. - #endif - #else - #ifdef __GNUC__ - #define ACTIVATOR_EXPORT __attribute__ ((dllexport)) - #define FRAMEWORK_EXPORT __attribute__ ((dllimport)) - #else - #define ACTIVATOR_EXPORT __declspec(dllexport) - #define FRAMEWORK_EXPORT __declspec(dllimport) // Note: actually gcc seems to also supports this syntax. - #endif - #endif - #define DLL_LOCAL -#else - #if __GNUC__ >= 4 - #define ACTIVATOR_EXPORT __attribute__ ((visibility ("default"))) - #define FRAMEWORK_EXPORT __attribute__ ((visibility ("default"))) - #define FRAMEWORK_LOCAL __attribute__ ((visibility ("hidden"))) - #else - #define ACTIVATOR_EXPORT - #define FRAMEWORK_EXPORT - #define FRAMEWORK_LOCAL - #endif -#endif - -#endif /* FRAMEWORK_EXPORTS_H_ */ http://git-wip-us.apache.org/repos/asf/celix/blob/a1c30887/framework/public/include/framework_listener.h ---------------------------------------------------------------------- diff --git a/framework/public/include/framework_listener.h b/framework/public/include/framework_listener.h deleted file mode 100644 index f390e3b..0000000 --- a/framework/public/include/framework_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 FrameworkListener Framework Listener - * @ingroup framework - * @{ - * - * \author Apache Celix Project Team - * \date Oct 8, 2013 - * \copyright Apache License, Version 2.0 - */ -#ifndef FRAMEWORK_LISTENER_H_ -#define FRAMEWORK_LISTENER_H_ - -typedef struct framework_listener *framework_listener_pt; - -#include "celix_errno.h" -#include "framework_event.h" -#ifdef __cplusplus -extern "C" { -#endif - -struct framework_listener { - void *handle; - - celix_status_t (*frameworkEvent)(void *listener, framework_event_pt event); -}; - -#ifdef __cplusplus -} -#endif - - -#endif /* FRAMEWORK_LISTENER_H_ */ - -/** - * @} - */ http://git-wip-us.apache.org/repos/asf/celix/blob/a1c30887/framework/public/include/listener_hook_service.h ---------------------------------------------------------------------- diff --git a/framework/public/include/listener_hook_service.h b/framework/public/include/listener_hook_service.h deleted file mode 100644 index 1f0c966..0000000 --- a/framework/public/include/listener_hook_service.h +++ /dev/null @@ -1,60 +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 Apache Celix Project Team - * \copyright Apache License, Version 2.0 - */ - -#ifndef LISTENER_HOOK_SERVICE_H_ -#define LISTENER_HOOK_SERVICE_H_ - - -typedef struct listener_hook *listener_hook_pt; -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; - 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/a1c30887/framework/public/include/manifest.h ---------------------------------------------------------------------- diff --git a/framework/public/include/manifest.h b/framework/public/include/manifest.h deleted file mode 100644 index eeccfbc..0000000 --- a/framework/public/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 Apache Celix Project Team - * \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/a1c30887/framework/public/include/module.h ---------------------------------------------------------------------- diff --git a/framework/public/include/module.h b/framework/public/include/module.h deleted file mode 100644 index bc85ef4..0000000 --- a/framework/public/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 Apache Celix Project Team - * \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/a1c30887/framework/public/include/requirement.h ---------------------------------------------------------------------- diff --git a/framework/public/include/requirement.h b/framework/public/include/requirement.h deleted file mode 100644 index febc62a..0000000 --- a/framework/public/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 Apache Celix Project Team - * \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/a1c30887/framework/public/include/service_event.h ---------------------------------------------------------------------- diff --git a/framework/public/include/service_event.h b/framework/public/include/service_event.h deleted file mode 100644 index a018b07..0000000 --- a/framework/public/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 Apache Celix Project Team - * \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/a1c30887/framework/public/include/service_factory.h ---------------------------------------------------------------------- diff --git a/framework/public/include/service_factory.h b/framework/public/include/service_factory.h deleted file mode 100644 index 84e383a..0000000 --- a/framework/public/include/service_factory.h +++ /dev/null @@ -1,60 +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_factory.h - * - * \date Jun 26, 2011 - * \author Apache Celix Project Team - * \copyright Apache License, Version 2.0 - */ - -#ifndef SERVICE_FACTORY_H_ -#define SERVICE_FACTORY_H_ -#ifdef __cplusplus -extern "C" { -#endif - -typedef struct service_factory service_factory_t; -typedef service_factory_t *service_factory_pt; -#ifdef __cplusplus -} -#endif - -#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, bundle_pt bundle, service_registration_pt registration, void **service); - - celix_status_t - (*ungetService)(void *handle, bundle_pt bundle, service_registration_pt registration, void **service); -}; - -#ifdef __cplusplus -} -#endif - -#endif /* SERVICE_FACTORY_H_ */ http://git-wip-us.apache.org/repos/asf/celix/blob/a1c30887/framework/public/include/service_listener.h ---------------------------------------------------------------------- diff --git a/framework/public/include/service_listener.h b/framework/public/include/service_listener.h deleted file mode 100644 index c887ba1..0000000 --- a/framework/public/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 Apache Celix Project Team - * \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/a1c30887/framework/public/include/service_reference.h ---------------------------------------------------------------------- diff --git a/framework/public/include/service_reference.h b/framework/public/include/service_reference.h deleted file mode 100644 index bb263f5..0000000 --- a/framework/public/include/service_reference.h +++ /dev/null @@ -1,72 +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 Apache Celix Project Team - * \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_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/a1c30887/framework/public/include/service_registration.h ---------------------------------------------------------------------- diff --git a/framework/public/include/service_registration.h b/framework/public/include/service_registration.h deleted file mode 100644 index 9265a00..0000000 --- a/framework/public/include/service_registration.h +++ /dev/null @@ -1,58 +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_registration.h - * - * \date Aug 6, 2010 - * \author Apache Celix Project Team - * \copyright Apache License, Version 2.0 - */ - -#ifndef SERVICE_REGISTRATION_H_ -#define SERVICE_REGISTRATION_H_ - -#include "celixbool.h" - -typedef struct serviceRegistration * service_registration_pt; - -#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_pt registration); - -FRAMEWORK_EXPORT celix_status_t -serviceRegistration_getProperties(service_registration_pt registration, properties_pt *properties); - -FRAMEWORK_EXPORT celix_status_t -serviceRegistration_setProperties(service_registration_pt registration, properties_pt properties); - -FRAMEWORK_EXPORT celix_status_t -serviceRegistration_getServiceName(service_registration_pt registration, const char **serviceName); - -#ifdef __cplusplus -} -#endif - -#endif /* SERVICE_REGISTRATION_H_ */ http://git-wip-us.apache.org/repos/asf/celix/blob/a1c30887/framework/public/include/service_registry.h ---------------------------------------------------------------------- diff --git a/framework/public/include/service_registry.h b/framework/public/include/service_registry.h deleted file mode 100644 index 9a2ec48..0000000 --- a/framework/public/include/service_registry.h +++ /dev/null @@ -1,103 +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 Apache Celix Project Team - * \copyright Apache License, Version 2.0 - */ - -#ifndef SERVICE_REGISTRY_H_ -#define SERVICE_REGISTRY_H_ - -typedef struct serviceRegistry * service_registry_pt; - -#include "properties.h" -#include "filter.h" -#include "service_factory.h" -#include "service_event.h" -#include "array_list.h" -#include "service_registration.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); - -#ifdef __cplusplus -} -#endif - -#endif /* SERVICE_REGISTRY_H_ */ http://git-wip-us.apache.org/repos/asf/celix/blob/a1c30887/framework/public/include/service_tracker.h ---------------------------------------------------------------------- diff --git a/framework/public/include/service_tracker.h b/framework/public/include/service_tracker.h deleted file mode 100644 index aa19d50..0000000 --- a/framework/public/include/service_tracker.h +++ /dev/null @@ -1,72 +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 Apache Celix Project Team - * \copyright Apache License, Version 2.0 - */ - -#ifndef SERVICE_TRACKER_H_ -#define SERVICE_TRACKER_H_ - -#include "service_listener.h" -#include "array_list.h" -#include "bundle_context.h" -#include "service_tracker_customizer.h" -#include "framework_exports.h" - -#ifdef __cplusplus -extern "C" { -#endif - -typedef struct serviceTracker *service_tracker_pt; - -FRAMEWORK_EXPORT celix_status_t -serviceTracker_create(bundle_context_pt context, const char *service, service_tracker_customizer_pt customizer, - service_tracker_pt *tracker); - -FRAMEWORK_EXPORT celix_status_t -serviceTracker_createWithFilter(bundle_context_pt context, const char *filter, service_tracker_customizer_pt customizer, - service_tracker_pt *tracker); - -FRAMEWORK_EXPORT celix_status_t serviceTracker_open(service_tracker_pt tracker); - -FRAMEWORK_EXPORT celix_status_t serviceTracker_close(service_tracker_pt tracker); - -FRAMEWORK_EXPORT celix_status_t serviceTracker_destroy(service_tracker_pt tracker); - -FRAMEWORK_EXPORT service_reference_pt serviceTracker_getServiceReference(service_tracker_pt tracker); - -FRAMEWORK_EXPORT array_list_pt serviceTracker_getServiceReferences(service_tracker_pt tracker); - -FRAMEWORK_EXPORT void *serviceTracker_getService(service_tracker_pt tracker); - -FRAMEWORK_EXPORT array_list_pt serviceTracker_getServices(service_tracker_pt tracker); - -FRAMEWORK_EXPORT void *serviceTracker_getServiceByReference(service_tracker_pt tracker, service_reference_pt reference); - -FRAMEWORK_EXPORT void serviceTracker_serviceChanged(service_listener_pt listener, service_event_pt event); - -#ifdef __cplusplus -} -#endif - -#endif /* SERVICE_TRACKER_H_ */ http://git-wip-us.apache.org/repos/asf/celix/blob/a1c30887/framework/public/include/service_tracker_customizer.h ---------------------------------------------------------------------- diff --git a/framework/public/include/service_tracker_customizer.h b/framework/public/include/service_tracker_customizer.h deleted file mode 100644 index 19672d8..0000000 --- a/framework/public/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 Apache Celix Project Team - * \copyright Apache License, Version 2.0 - */ - - -#ifndef service_tracker_customizer_t_H_ -#define service_tracker_customizer_t_H_ - -#include -#include - -#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/a1c30887/framework/public/include/wire.h ---------------------------------------------------------------------- diff --git a/framework/public/include/wire.h b/framework/public/include/wire.h deleted file mode 100644 index 9bb9e02..0000000 --- a/framework/public/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 Apache Celix Project Team - * \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 wire 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_ */