/*
- * Copyright (c) 1998-2000 Apple Computer, Inc. All rights reserved.
+ * Copyright (c) 1998-2008 Apple Inc. All rights reserved.
*
- * @APPLE_LICENSE_HEADER_START@
+ * @APPLE_OSREFERENCE_LICENSE_HEADER_START@
*
- * The contents of this file constitute Original Code as defined in and
- * are subject to the Apple Public Source License Version 1.1 (the
- * "License"). You may not use this file except in compliance with the
- * License. Please obtain a copy of the License at
- * http://www.apple.com/publicsource and read it before using this file.
+ * This file contains Original Code and/or Modifications of Original Code
+ * as defined in and that are subject to the Apple Public Source License
+ * Version 2.0 (the 'License'). You may not use this file except in
+ * compliance with the License. The rights granted to you under the License
+ * may not be used to create, or enable the creation or redistribution of,
+ * unlawful or unlicensed copies of an Apple operating system, or to
+ * circumvent, violate, or enable the circumvention or violation of, any
+ * terms of an Apple operating system software license agreement.
*
- * This Original Code and all software distributed under the License are
- * distributed on an "AS IS" basis, WITHOUT WARRANTY OF ANY KIND, EITHER
+ * Please obtain a copy of the License at
+ * http://www.opensource.apple.com/apsl/ and read it before using this file.
+ *
+ * The Original Code and all software distributed under the License are
+ * distributed on an 'AS IS' basis, WITHOUT WARRANTY OF ANY KIND, EITHER
* EXPRESS OR IMPLIED, AND APPLE HEREBY DISCLAIMS ALL SUCH WARRANTIES,
* INCLUDING WITHOUT LIMITATION, ANY WARRANTIES OF MERCHANTABILITY,
- * FITNESS FOR A PARTICULAR PURPOSE OR NON-INFRINGEMENT. Please see the
- * License for the specific language governing rights and limitations
- * under the License.
+ * FITNESS FOR A PARTICULAR PURPOSE, QUIET ENJOYMENT OR NON-INFRINGEMENT.
+ * Please see the License for the specific language governing rights and
+ * limitations under the License.
*
- * @APPLE_LICENSE_HEADER_END@
- */
-/*
- * Copyright (c) 1991-1999 Apple Computer, Inc. All rights reserved.
- *
- * HISTORY
- *
- * 29-Jan-91 Portions from IODevice.m, Doug Mitchell at NeXT, Created.
- * 18-Jun-98 start IOKit objc
- * 10-Nov-98 start iokit cpp
- * 25-Feb-99 sdouglas, add threads and locks to ensure deadlock
- *
+ * @APPLE_OSREFERENCE_LICENSE_HEADER_END@
*/
#include <IOKit/system.h>
#include <IOKit/IOService.h>
+#include <libkern/OSDebug.h>
#include <libkern/c++/OSContainers.h>
+#include <libkern/c++/OSKext.h>
#include <libkern/c++/OSUnserialize.h>
#include <IOKit/IOCatalogue.h>
+#include <IOKit/IOCommand.h>
#include <IOKit/IODeviceMemory.h>
#include <IOKit/IOInterrupts.h>
#include <IOKit/IOInterruptController.h>
#include <IOKit/IOPlatformExpert.h>
#include <IOKit/IOMessage.h>
#include <IOKit/IOLib.h>
-#include <IOKit/IOKitKeys.h>
+#include <IOKit/IOKitKeysPrivate.h>
#include <IOKit/IOBSD.h>
#include <IOKit/IOUserClient.h>
+#include <IOKit/IOWorkLoop.h>
+#include <IOKit/IOTimeStamp.h>
+#include <mach/sync_policy.h>
+#include <IOKit/assert.h>
+#include <sys/errno.h>
-//#define LESS_THREAD_CREATE
-//#define LOG kprintf
-#define LOG IOLog
+#define LOG kprintf
+//#define LOG IOLog
#include "IOServicePrivate.h"
-#include <mach/sync_policy.h>
-
-#include <IOKit/assert.h>
-#include <sys/errno.h>
+// take lockForArbitration before LOCKNOTIFY
/* * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * */
/* * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * */
static IOPlatformExpert * gIOPlatform;
+static class IOPMrootDomain * gIOPMRootDomain;
const IORegistryPlane * gIOServicePlane;
const IORegistryPlane * gIOPowerPlane;
const OSSymbol * gIODeviceMemoryKey;
const OSSymbol * gIONameMatchedKey;
const OSSymbol * gIOPropertyMatchKey;
const OSSymbol * gIOLocationMatchKey;
+const OSSymbol * gIOParentMatchKey;
const OSSymbol * gIOPathMatchKey;
const OSSymbol * gIOMatchCategoryKey;
const OSSymbol * gIODefaultMatchCategoryKey;
const OSSymbol * gIOMatchedServiceCountKey;
+const OSSymbol * gIOMapperIDKey;
const OSSymbol * gIOUserClientClassKey;
const OSSymbol * gIOKitDebugKey;
const OSSymbol * gIOCommandPoolSizeKey;
+const OSSymbol * gIOConsoleUsersKey;
+const OSSymbol * gIOConsoleSessionUIDKey;
+const OSSymbol * gIOConsoleUsersSeedKey;
+const OSSymbol * gIOConsoleSessionOnConsoleKey;
+const OSSymbol * gIOConsoleSessionSecureInputPIDKey;
+
static int gIOResourceGenerationCount;
const OSSymbol * gIOServiceKey;
const OSSymbol * gIOGeneralInterest;
const OSSymbol * gIOBusyInterest;
const OSSymbol * gIOAppPowerStateInterest;
+const OSSymbol * gIOPriorityPowerStateInterest;
static OSDictionary * gNotifications;
static IORecursiveLock * gNotificationLock;
static int gNumWaitingThreads;
static IOLock * gIOServiceBusyLock;
+static thread_t gIOTerminateThread;
+static UInt32 gIOTerminateWork;
+static OSArray * gIOTerminatePhase2List;
+static OSArray * gIOStopList;
+static OSArray * gIOStopProviderList;
+static OSArray * gIOFinalizeList;
+
+static SInt32 gIOConsoleUsersSeed;
+static OSData * gIOConsoleUsersSeedValue;
+
+extern const OSSymbol * gIODTPHandleKey;
+
+const OSSymbol * gIOPlatformSleepActionKey;
+const OSSymbol * gIOPlatformWakeActionKey;
+const OSSymbol * gIOPlatformQuiesceActionKey;
+const OSSymbol * gIOPlatformActiveActionKey;
+
+const OSSymbol * gIOPlatformFunctionHandlerSet;
+
/* * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * */
#define LOCKREADNOTIFY() \
#define LOCKWRITE2READNOTIFY()
#define UNLOCKNOTIFY() \
IORecursiveLockUnlock( gNotificationLock )
+#define SLEEPNOTIFY(event) \
+ IORecursiveLockSleep( gNotificationLock, (void *)(event), THREAD_UNINT )
+#define SLEEPNOTIFYTO(event, deadline) \
+ IORecursiveLockSleepDeadline( gNotificationLock, (void *)(event), deadline, THREAD_UNINT )
+#define WAKEUPNOTIFY(event) \
+ IORecursiveLockWakeup( gNotificationLock, (void *)(event), /* wake one */ false )
+
+#define randomDelay() \
+ int del = read_processor_clock(); \
+ del = (((int)IOThreadSelf()) ^ del ^ (del >> 10)) & 0x3ff; \
+ IOSleep( del );
+
+/* * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * */
+
+#define queue_element(entry, element, type, field) do { \
+ vm_address_t __ele = (vm_address_t) (entry); \
+ __ele -= -4 + ((size_t)(&((type) 4)->field)); \
+ (element) = (type) __ele; \
+ } while(0)
+
+#define iterqueue(que, elt) \
+ for (queue_entry_t elt = queue_first(que); \
+ !queue_end(que, elt); \
+ elt = queue_next(elt))
/* * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * */
static queue_head_t gArbitrationLockQueueFree;
static IOLock * gArbitrationLockQueueLock;
+bool IOService::isInactive( void ) const
+ { return( 0 != (kIOServiceInactiveState & getState())); }
+
+
+/* * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * */
+
+#define IOServiceTrace(csc, a, b, c, d) { \
+ if(kIOTraceIOService & gIOKitDebug) { \
+ KERNEL_DEBUG_CONSTANT(IODBG_IOSERVICE(csc), a, b, c, d, 0); \
+ } \
+}
+
+/* * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * */
+
+#if defined(__i386__) || defined(__x86_64__)
+
+// Only used by the intel implementation of
+// IOService::requireMaxBusStall(UInt32 ns)
+// IOService::requireMaxInterruptDelay(uint32_t ns)
+struct CpuDelayEntry
+{
+ IOService * fService;
+ UInt32 fMaxDelay;
+ UInt32 fDelayType;
+};
+
+enum {
+ kCpuDelayBusStall, kCpuDelayInterrupt,
+ kCpuNumDelayTypes
+};
+
+static OSData *sCpuDelayData = OSData::withCapacity(8 * sizeof(CpuDelayEntry));
+static IORecursiveLock *sCpuDelayLock = IORecursiveLockAlloc();
+static OSArray *sCpuLatencyHandlers[kCpuNumDelayTypes];
+const OSSymbol *sCPULatencyFunctionName[kCpuNumDelayTypes];
+
+static void
+requireMaxCpuDelay(IOService * service, UInt32 ns, UInt32 delayType);
+static IOReturn
+setLatencyHandler(UInt32 delayType, IOService * target, bool enable);
+
+#endif /* defined(__i386__) || defined(__x86_64__) */
+
/* * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * */
void IOService::initialize( void )
gIONameMatchedKey = OSSymbol::withCStringNoCopy( kIONameMatchedKey );
gIOPropertyMatchKey = OSSymbol::withCStringNoCopy( kIOPropertyMatchKey );
gIOPathMatchKey = OSSymbol::withCStringNoCopy( kIOPathMatchKey );
- gIOLocationMatchKey = OSSymbol::withCStringNoCopy( kIOLocationMatchKey );
+ gIOLocationMatchKey = OSSymbol::withCStringNoCopy( kIOLocationMatchKey );
+ gIOParentMatchKey = OSSymbol::withCStringNoCopy( kIOParentMatchKey );
gIOMatchCategoryKey = OSSymbol::withCStringNoCopy( kIOMatchCategoryKey );
gIODefaultMatchCategoryKey = OSSymbol::withCStringNoCopy(
gIOInterruptSpecifiersKey
= OSSymbol::withCStringNoCopy("IOInterruptSpecifiers");
+ gIOMapperIDKey = OSSymbol::withCStringNoCopy(kIOMapperIDKey);
+
gIOKitDebugKey = OSSymbol::withCStringNoCopy( kIOKitDebugKey );
gIOCommandPoolSizeKey = OSSymbol::withCStringNoCopy( kIOCommandPoolSizeKey );
gIOGeneralInterest = OSSymbol::withCStringNoCopy( kIOGeneralInterest );
gIOBusyInterest = OSSymbol::withCStringNoCopy( kIOBusyInterest );
gIOAppPowerStateInterest = OSSymbol::withCStringNoCopy( kIOAppPowerStateInterest );
+ gIOPriorityPowerStateInterest = OSSymbol::withCStringNoCopy( kIOPriorityPowerStateInterest );
gNotifications = OSDictionary::withCapacity( 1 );
gIOPublishNotification = OSSymbol::withCStringNoCopy(
kIOTerminatedNotification );
gIOServiceKey = OSSymbol::withCStringNoCopy( kIOServiceClass);
+ gIOConsoleUsersKey = OSSymbol::withCStringNoCopy( kIOConsoleUsersKey);
+ gIOConsoleSessionUIDKey = OSSymbol::withCStringNoCopy( kIOConsoleSessionUIDKey);
+ gIOConsoleUsersSeedKey = OSSymbol::withCStringNoCopy( kIOConsoleUsersSeedKey);
+ gIOConsoleSessionOnConsoleKey = OSSymbol::withCStringNoCopy( kIOConsoleSessionOnConsoleKey);
+ gIOConsoleSessionSecureInputPIDKey = OSSymbol::withCStringNoCopy( kIOConsoleSessionSecureInputPIDKey);
+ gIOConsoleUsersSeedValue = OSData::withBytesNoCopy(&gIOConsoleUsersSeed, sizeof(gIOConsoleUsersSeed));
+
+ gIOPlatformSleepActionKey = OSSymbol::withCStringNoCopy(kIOPlatformSleepActionKey);
+ gIOPlatformWakeActionKey = OSSymbol::withCStringNoCopy(kIOPlatformWakeActionKey);
+ gIOPlatformQuiesceActionKey = OSSymbol::withCStringNoCopy(kIOPlatformQuiesceActionKey);
+ gIOPlatformActiveActionKey = OSSymbol::withCStringNoCopy(kIOPlatformActiveActionKey);
+
+ gIOPlatformFunctionHandlerSet = OSSymbol::withCStringNoCopy(kIOPlatformFunctionHandlerSet);
+#if defined(__i386__) || defined(__x86_64__)
+ sCPULatencyFunctionName[kCpuDelayBusStall] = OSSymbol::withCStringNoCopy(kIOPlatformFunctionHandlerMaxBusDelay);
+ sCPULatencyFunctionName[kCpuDelayInterrupt] = OSSymbol::withCStringNoCopy(kIOPlatformFunctionHandlerMaxInterruptDelay);
+#endif
gNotificationLock = IORecursiveLockAlloc();
assert( gIOServicePlane && gIODeviceMemoryKey
&& gIOProviderClassKey && gIONameMatchKey && gIONameMatchedKey
&& gIOMatchCategoryKey && gIODefaultMatchCategoryKey
&& gIOPublishNotification && gIOMatchedNotification
- && gIOTerminatedNotification && gIOServiceKey );
+ && gIOTerminatedNotification && gIOServiceKey
+ && gIOConsoleUsersKey && gIOConsoleSessionUIDKey
+ && gIOConsoleSessionOnConsoleKey && gIOConsoleSessionSecureInputPIDKey
+ && gIOConsoleUsersSeedKey && gIOConsoleUsersSeedValue);
gJobsLock = IOLockAlloc();
gJobs = OSOrderedSet::withCapacity( 10 );
assert( gArbitrationLockQueueLock );
-#ifdef LESS_THREAD_CREATE
- for( int i = 0; i < kMaxConfigThreads; i++)
- _IOConfigThread::configThread();
-#endif
-
+ gIOTerminatePhase2List = OSArray::withCapacity( 2 );
+ gIOStopList = OSArray::withCapacity( 16 );
+ gIOStopProviderList = OSArray::withCapacity( 16 );
+ gIOFinalizeList = OSArray::withCapacity( 16 );
+ assert( gIOTerminatePhase2List && gIOStopList && gIOStopProviderList && gIOFinalizeList );
}
/* * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * */
// The default score is from the property table, & may be altered
// during probe to change the start order.
-IOService * IOService::probe( IOService * /* provider */,
- SInt32 * /* score */)
+IOService * IOService::probe( IOService * provider,
+ SInt32 * score )
{
return( this );
}
return( true );
}
-void IOService::stop( IOService * /* provider */ )
+void IOService::stop( IOService * provider )
+{
+}
+
+void IOService::free( void )
{
+ requireMaxBusStall(0);
+ requireMaxInterruptDelay(0);
+ if( getPropertyTable())
+ unregisterAllInterest();
+ PMfree();
+ super::free();
}
/*
provider->unlockForArbitration();
} else {
-
gIOServiceRoot = this;
ok = attachToParent( getRegistryRoot(), gIOServicePlane);
- gIOResources->attachToParent( getRegistryRoot(),
- gIOServicePlane );
- publishResource("IOKit");
}
return( ok );
void IOService::detach( IOService * provider )
{
+ IOService * newProvider = 0;
+ SInt32 busy;
+ bool adjParent;
+
if( gIOKitDebug & kIOLogAttach)
LOG("%s::detach(%s)\n", getName(), provider->getName());
lockForArbitration();
- if( (__state[1] & kIOServiceBusyStateMask)
- && (provider == getProvider()))
- provider->adjustBusy( -1 );
+ adjParent = ((busy = (__state[1] & kIOServiceBusyStateMask))
+ && (provider == getProvider()));
detachFromParent( provider, gIOServicePlane );
+ if( busy) {
+ newProvider = getProvider();
+ if( busy && (__state[1] & kIOServiceTermPhase3State) && (0 == newProvider))
+ _adjustBusy( -busy );
+ }
+
unlockForArbitration();
+
+ if( newProvider) {
+ newProvider->lockForArbitration();
+ newProvider->_adjustBusy(1);
+ newProvider->unlockForArbitration();
+ }
+
+ // check for last client detach from a terminated service
+ if( provider->lockForArbitration( true )) {
+ if( adjParent)
+ provider->_adjustBusy( -1 );
+ if( (provider->__state[1] & kIOServiceTermPhase3State)
+ && (0 == provider->getClient())) {
+ provider->scheduleFinalize();
+ }
+ provider->unlockForArbitration();
+ }
}
/*
* Register instance - publish it for matching
*/
-void IOService::registerService( IOOptionBits options = 0 )
+void IOService::registerService( IOOptionBits options )
{
char * pathBuf;
const char * path;
startMatching( options );
}
-void IOService::startMatching( IOOptionBits options = 0 )
+void IOService::startMatching( IOOptionBits options )
{
IOService * provider;
+ UInt32 prevBusy = 0;
bool needConfig;
+ bool needWake = false;
bool ok;
bool sync;
+ bool waitAgain;
lockForArbitration();
sync = (options & kIOServiceSynchronous)
|| ((provider = getProvider())
&& (provider->__state[1] & kIOServiceSynchronousState));
- if( sync)
- __state[1] |= kIOServiceSynchronousState;
- else
- __state[1] &= ~kIOServiceSynchronousState;
- needConfig = (0 == (__state[1] & kIOServiceConfigState))
- && (0 == (__state[0] & kIOServiceInactiveState))
- && (kIOServiceRegisteredState !=
- (__state[0] & (kIOServiceRegisteredState
- | kIOServiceMatchedState)));
- __state[1] |= kIOServiceConfigState;
+ if ( options & kIOServiceAsynchronous )
+ sync = false;
+
+ needConfig = (0 == (__state[1] & (kIOServiceNeedConfigState | kIOServiceConfigState)))
+ && (0 == (__state[0] & kIOServiceInactiveState));
+
+ __state[1] |= kIOServiceNeedConfigState;
+
// __state[0] &= ~kIOServiceInactiveState;
// if( sync) LOG("OSKernelStackRemaining = %08x @ %s\n",
// OSKernelStackRemaining(), getName());
+ if( needConfig) {
+ prevBusy = _adjustBusy( 1 );
+ needWake = (0 != (kIOServiceSyncPubState & __state[1]));
+ }
+
+ if( sync)
+ __state[1] |= kIOServiceSynchronousState;
+ else
+ __state[1] &= ~kIOServiceSynchronousState;
+
unlockForArbitration();
if( needConfig) {
- adjustBusy( 1 );
- if( sync) {
- doServiceMatch( options );
- waitQuiet();
- } else
+
+ if( needWake) {
+ IOLockLock( gIOServiceBusyLock );
+ thread_wakeup( (event_t) this/*&__state[1]*/ );
+ IOLockUnlock( gIOServiceBusyLock );
+
+ } else if( !sync || (kIOServiceAsynchronous & options)) {
+
ok = (0 != _IOServiceJob::startJob( this, kMatchNubJob, options ));
+
+ } else do {
+
+ if( (__state[1] & kIOServiceNeedConfigState))
+ doServiceMatch( options );
+
+ lockForArbitration();
+ IOLockLock( gIOServiceBusyLock );
+
+ waitAgain = (prevBusy < (__state[1] & kIOServiceBusyStateMask));
+ if( waitAgain)
+ __state[1] |= kIOServiceSyncPubState | kIOServiceBusyWaiterState;
+ else
+ __state[1] &= ~kIOServiceSyncPubState;
+
+ unlockForArbitration();
+
+ if( waitAgain)
+ assert_wait( (event_t) this/*&__state[1]*/, THREAD_UNINT);
+
+ IOLockUnlock( gIOServiceBusyLock );
+ if( waitAgain)
+ thread_block(THREAD_CONTINUE_NULL);
+
+ } while( waitAgain );
}
}
IOReturn IOService::catalogNewDrivers( OSOrderedSet * newTables )
{
OSDictionary * table;
- OSIterator * iter;
+ OSSet * set;
+ OSSet * allSet = 0;
IOService * service;
#if IOMATCHDEBUG
SInt32 count = 0;
while( (table = (OSDictionary *) newTables->getFirstObject())) {
LOCKWRITENOTIFY();
- iter = (OSIterator *) getExistingServices( table,
- kIOServiceMatchedState );
+ set = (OSSet *) copyExistingServices( table,
+ kIOServiceRegisteredState,
+ kIOServiceExistingSet);
UNLOCKNOTIFY();
- if( iter) {
- while( (service = (IOService *) iter->getNextObject())) {
- service->startMatching();
+ if( set) {
+
#if IOMATCHDEBUG
- count++;
+ count += set->getCount();
#endif
+ if (allSet) {
+ allSet->merge((const OSSet *) set);
+ set->release();
}
- iter->release();
+ else
+ allSet = set;
}
+
#if IOMATCHDEBUG
if( getDebugFlags( table ) & kIOLogMatch)
- LOG("Matching service count = %ld\n", count);
+ LOG("Matching service count = %ld\n", (long)count);
#endif
newTables->removeObject(table);
}
+ if (allSet) {
+ while( (service = (IOService *) allSet->getAnyObject())) {
+ service->startMatching(kIOServiceAsynchronous);
+ allSet->removeObject(service);
+ }
+ allSet->release();
+ }
+
newTables->release();
return( kIOReturnSuccess );
}
_IOServiceJob * _IOServiceJob::startJob( IOService * nub, int type,
- IOOptionBits options = 0 )
+ IOOptionBits options )
{
_IOServiceJob * job;
void *param3, void *param4 )
{
IOReturn result = kIOReturnUnsupported;
- IOService *provider = getProvider();
-
- if (provider != 0) {
+ IOService *provider;
+
+ if (gIOPlatformFunctionHandlerSet == functionName)
+ {
+#if defined(__i386__) || defined(__x86_64__)
+ const OSSymbol * functionHandlerName = (const OSSymbol *) param1;
+ IOService * target = (IOService *) param2;
+ bool enable = (param3 != 0);
+
+ if (sCPULatencyFunctionName[kCpuDelayBusStall] == functionHandlerName)
+ result = setLatencyHandler(kCpuDelayBusStall, target, enable);
+ else if (sCPULatencyFunctionName[kCpuDelayInterrupt] == param1)
+ result = setLatencyHandler(kCpuDelayInterrupt, target, enable);
+#endif /* defined(__i386__) || defined(__x86_64__) */
+ }
+
+ if ((kIOReturnUnsupported == result) && (provider = getProvider())) {
result = provider->callPlatformFunction(functionName, waitForFunction,
param1, param2, param3, param4);
}
/*
- * Platform expert accessors
+ * Accessors for global services
*/
IOPlatformExpert * IOService::getPlatform( void )
return( gIOPlatform);
}
+class IOPMrootDomain * IOService::getPMRootDomain( void )
+{
+ return( gIOPMRootDomain);
+}
+
+IOService * IOService::getResourceService( void )
+{
+ return( gIOResources );
+}
+
void IOService::setPlatform( IOPlatformExpert * platform)
{
gIOPlatform = platform;
+ gIOResources->attachToParent( gIOServiceRoot, gIOServicePlane );
+}
+
+void IOService::setPMRootDomain( class IOPMrootDomain * rootDomain)
+{
+ gIOPMRootDomain = rootDomain;
+ publishResource("IOKit");
}
/*
* Stacking change
*/
-bool IOService::lockForArbitration( bool isSuccessRequired = true )
+bool IOService::lockForArbitration( bool isSuccessRequired )
{
bool found;
bool success;
link );
// wake the victim
- thread_wakeup_one(victim);
+ IOLockWakeup( gArbitrationLockQueueLock,
+ victim,
+ /* one thread */ true );
// allow this thread to proceed (ie. wait)
success = true; // (put request on wait queue)
link );
// declare that this thread will wait for a given event
-restart_sleep: assert_wait( element,
- element->required ? THREAD_UNINT
- : THREAD_INTERRUPTIBLE );
+restart_sleep: wait_result = assert_wait( element,
+ element->required ? THREAD_UNINT
+ : THREAD_INTERRUPTIBLE );
// unlock global access
IOUnlock( gArbitrationLockQueueLock );
// put thread to sleep, waiting for our event to fire...
- wait_result = thread_block((void (*)(void)) 0);
+ if (wait_result == THREAD_WAITING)
+ wait_result = thread_block(THREAD_CONTINUE_NULL);
+
// ...and we've been woken up; we might be in one of two states:
// (a) we've been aborted and our queue element is not on
link );
// wake the waiting thread
- thread_wakeup_one(element);
+ IOLockWakeup( gArbitrationLockQueueLock,
+ element,
+ /* one thread */ true );
}
}
// send a message to a client or interested party of this service
IOReturn IOService::messageClient( UInt32 type, OSObject * client,
- void * argument = 0, vm_size_t argSize = 0 )
+ void * argument, vm_size_t argSize )
{
IOReturn ret;
IOService * service;
_IOServiceNotifierInvocation *, link );
if( kIOServiceNotifyWaiter & notify->state) {
notify->state &= ~kIOServiceNotifyWaiter;
- thread_wakeup( (event_t) notify);
+ WAKEUPNOTIFY( notify );
}
UNLOCKNOTIFY();
return( ret );
}
+static void
+applyToInterestNotifiers(const IORegistryEntry *target,
+ const OSSymbol * typeOfInterest,
+ OSObjectApplierFunction applier,
+ void * context )
+{
+ OSArray * copyArray = 0;
+
+ LOCKREADNOTIFY();
+
+ IOCommand *notifyList =
+ OSDynamicCast( IOCommand, target->getProperty( typeOfInterest ));
+
+ if( notifyList) {
+ copyArray = OSArray::withCapacity(1);
+
+ // iterate over queue, entry is set to each element in the list
+ iterqueue(¬ifyList->fCommandChain, entry) {
+ _IOServiceInterestNotifier * notify;
+
+ queue_element(entry, notify, _IOServiceInterestNotifier *, chain);
+ copyArray->setObject(notify);
+ }
+ }
+ UNLOCKNOTIFY();
+
+ if( copyArray) {
+ unsigned int index;
+ OSObject * next;
+
+ for( index = 0; (next = copyArray->getObject( index )); index++)
+ (*applier)(next, context);
+ copyArray->release();
+ }
+}
+
void IOService::applyToInterested( const OSSymbol * typeOfInterest,
OSObjectApplierFunction applier,
void * context )
{
- OSArray * array;
- unsigned int index;
- OSObject * next;
- OSArray * copyArray;
-
- applyToClients( (IOServiceApplierFunction) applier, context );
-
- LOCKREADNOTIFY();
- array = OSDynamicCast( OSArray, getProperty( typeOfInterest ));
- if( array) {
- copyArray = OSArray::withArray( array );
- UNLOCKNOTIFY();
- if( copyArray) {
- for( index = 0;
- (next = array->getObject( index ));
- index++) {
- (*applier)(next, context);
- }
- copyArray->release();
- }
- } else
- UNLOCKNOTIFY();
+ if (gIOGeneralInterest == typeOfInterest)
+ applyToClients( (IOServiceApplierFunction) applier, context );
+ applyToInterestNotifiers(this, typeOfInterest, applier, context);
}
struct MessageClientsContext {
// send a message to all clients
IOReturn IOService::messageClients( UInt32 type,
- void * argument = 0, vm_size_t argSize = 0 )
+ void * argument, vm_size_t argSize )
{
MessageClientsContext context;
IOServiceInterestHandler handler, void * target, void * ref )
{
_IOServiceInterestNotifier * notify = 0;
- OSArray * set;
if( (typeOfInterest != gIOGeneralInterest)
&& (typeOfInterest != gIOBusyInterest)
- && (typeOfInterest != gIOAppPowerStateInterest))
+ && (typeOfInterest != gIOAppPowerStateInterest)
+ && (typeOfInterest != gIOPriorityPowerStateInterest))
return( 0 );
lockForArbitration();
////// queue
LOCKWRITENOTIFY();
- if( 0 == (set = (OSArray *) getProperty( typeOfInterest ))) {
- set = OSArray::withCapacity( 1 );
- if( set) {
- setProperty( typeOfInterest, set );
- set->release();
- }
- }
- notify->whence = set;
- if( set)
- set->setObject( notify );
+
+ // Get the head of the notifier linked list
+ IOCommand *notifyList = (IOCommand *) getProperty( typeOfInterest );
+ if (!notifyList || !OSDynamicCast(IOCommand, notifyList)) {
+ notifyList = OSTypeAlloc(IOCommand);
+ if (notifyList) {
+ notifyList->init();
+ setProperty( typeOfInterest, notifyList);
+ notifyList->release();
+ }
+ }
+
+ if (notifyList) {
+ enqueue(¬ifyList->fCommandChain, ¬ify->chain);
+ notify->retain(); // ref'ed while in list
+ }
+
UNLOCKNOTIFY();
}
}
return( notify );
}
-static void cleanInterestArray( OSObject * object )
+static void cleanInterestList( OSObject * head )
{
- OSArray * array;
- unsigned int index;
- _IOServiceInterestNotifier * next;
-
- if( (array = OSDynamicCast( OSArray, object))) {
- LOCKWRITENOTIFY();
- for( index = 0;
- (next = (_IOServiceInterestNotifier *)
- array->getObject( index ));
- index++) {
- next->whence = 0;
- }
- UNLOCKNOTIFY();
+ IOCommand *notifyHead = OSDynamicCast(IOCommand, head);
+ if (!notifyHead)
+ return;
+
+ LOCKWRITENOTIFY();
+ while ( queue_entry_t entry = dequeue(¬ifyHead->fCommandChain) ) {
+ queue_next(entry) = queue_prev(entry) = 0;
+
+ _IOServiceInterestNotifier * notify;
+
+ queue_element(entry, notify, _IOServiceInterestNotifier *, chain);
+ notify->release();
}
+ UNLOCKNOTIFY();
}
void IOService::unregisterAllInterest( void )
{
- cleanInterestArray( getProperty( gIOGeneralInterest ));
- cleanInterestArray( getProperty( gIOBusyInterest ));
+ cleanInterestList( getProperty( gIOGeneralInterest ));
+ cleanInterestList( getProperty( gIOBusyInterest ));
+ cleanInterestList( getProperty( gIOAppPowerStateInterest ));
+ cleanInterestList( getProperty( gIOPriorityPowerStateInterest ));
}
/*
}
if( doWait) {
state |= kIOServiceNotifyWaiter;
- assert_wait( this, THREAD_UNINT);
- UNLOCKNOTIFY();
- thread_block((void (*)(void)) 0);
- LOCKWRITENOTIFY();
+ SLEEPNOTIFY(this);
}
} while( doWait );
{
LOCKWRITENOTIFY();
- if( whence) {
- whence->removeObject(whence->getNextIndexOfObject(
- (OSObject *) this, 0 ));
- whence = 0;
+ if( queue_next( &chain )) {
+ remqueue( 0, &chain);
+ queue_next( &chain) = queue_prev( &chain) = 0;
+ release();
}
state &= ~kIOServiceNotifyEnable;
UNLOCKNOTIFY();
}
+/* * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * */
/*
- * Terminate
+ * Termination
*/
-// a method in case someone needs to override it
-bool IOService::terminateClient( IOService * client, IOOptionBits options )
+#define tailQ(o) setObject(o)
+#define headQ(o) setObject(0, o)
+#define TLOG(fmt, args...) { if(kIOLogYield & gIOKitDebug) IOLog(fmt, ## args); }
+
+static void _workLoopAction( IOWorkLoop::Action action,
+ IOService * service,
+ void * p0 = 0, void * p1 = 0,
+ void * p2 = 0, void * p3 = 0 )
+{
+ IOWorkLoop * wl;
+
+ if( (wl = service->getWorkLoop())) {
+ wl->retain();
+ wl->runAction( action, service, p0, p1, p2, p3 );
+ wl->release();
+ } else
+ (*action)( service, p0, p1, p2, p3 );
+}
+
+bool IOService::requestTerminate( IOService * provider, IOOptionBits options )
{
bool ok;
- if( client->isParent( this, gIOServicePlane, true))
- // we are the clients only provider
- ok = client->terminate( options );
- else
- ok = true;
+ // if its our only provider
+ ok = isParent( provider, gIOServicePlane, true);
+
+ // -- compat
+ if( ok) {
+ provider->terminateClient( this, options | kIOServiceRecursing );
+ ok = (0 != (__state[1] & kIOServiceRecursing));
+ }
+ // --
return( ok );
}
-struct TerminateClientsContext {
- IOService * provider;
- IOOptionBits options;
-};
-
-static void terminateInterestApplier( OSObject * object, void * ctx )
+bool IOService::terminatePhase1( IOOptionBits options )
{
- TerminateClientsContext * context = (TerminateClientsContext *) ctx;
+ IOService * victim;
+ IOService * client;
+ OSIterator * iter;
+ OSArray * makeInactive;
+ bool ok;
+ bool didInactive;
+ bool startPhase2 = false;
+
+ TLOG("%s::terminatePhase1(%08llx)\n", getName(), (long long)options);
+
+ uint64_t regID = getRegistryEntryID();
+ IOServiceTrace(
+ IOSERVICE_TERMINATE_PHASE1,
+ (uintptr_t) regID,
+ (uintptr_t) (regID >> 32),
+ (uintptr_t) this,
+ (uintptr_t) options);
+
+ // -- compat
+ if( options & kIOServiceRecursing) {
+ __state[1] |= kIOServiceRecursing;
+ return( true );
+ }
+ // --
- context->provider->messageClient( kIOMessageServiceIsTerminated,
- object, (void *) context->options );
-}
+ makeInactive = OSArray::withCapacity( 16 );
+ if( !makeInactive)
+ return( false );
-static void terminateClientsApplier( IOService * client, void * ctx )
-{
- TerminateClientsContext * context = (TerminateClientsContext *) ctx;
+ victim = this;
+ victim->retain();
- if( gIOKitDebug & kIOLogYield)
- LOG("%s::terminateClient(%s,%08lx)\n",
- context->provider->getName(),
- client->getName(), context->options);
+ while( victim ) {
- context->provider->terminateClient( client,
- ((context->options) | kIOServiceRecursing) & ~kIOServiceSynchronous );
-}
+ didInactive = victim->lockForArbitration( true );
+ if( didInactive) {
+ didInactive = (0 == (victim->__state[0] & kIOServiceInactiveState));
+ if( didInactive) {
+ victim->__state[0] |= kIOServiceInactiveState;
+ victim->__state[0] &= ~(kIOServiceRegisteredState | kIOServiceMatchedState
+ | kIOServiceFirstPublishState | kIOServiceFirstMatchState);
+ victim->_adjustBusy( 1 );
+ }
+ victim->unlockForArbitration();
+ }
+ if( victim == this)
+ startPhase2 = didInactive;
+ if( didInactive) {
-static void terminateRequestClose( IOService * client, void * ctx )
-{
- TerminateClientsContext * context = (TerminateClientsContext *) ctx;
- IOService * provider = context->provider;
+ victim->deliverNotification( gIOTerminatedNotification, 0, 0xffffffff );
+ IOUserClient::destroyUserReferences( victim );
- if( provider->isOpen( client)) {
- if( gIOKitDebug & kIOLogYield)
- LOG("%s::terminate request close(%s,%08lx)\n",
- provider->getName(),
- client->getName(), context->options);
- provider->messageClient( kIOMessageServiceIsRequestingClose,
- client, (void *) context->options );
+ iter = victim->getClientIterator();
+ if( iter) {
+ while( (client = (IOService *) iter->getNextObject())) {
+ TLOG("%s::requestTerminate(%s, %08llx)\n",
+ client->getName(), victim->getName(), (long long)options);
+ ok = client->requestTerminate( victim, options );
+ TLOG("%s::requestTerminate(%s, ok = %d)\n",
+ client->getName(), victim->getName(), ok);
+
+ uint64_t regID1 = client->getRegistryEntryID();
+ uint64_t regID2 = victim->getRegistryEntryID();
+ IOServiceTrace(
+ (ok ? IOSERVICE_TERMINATE_REQUEST_OK
+ : IOSERVICE_TERMINATE_REQUEST_FAIL),
+ (uintptr_t) regID1,
+ (uintptr_t) (regID1 >> 32),
+ (uintptr_t) regID2,
+ (uintptr_t) (regID2 >> 32));
+
+ if( ok)
+ makeInactive->setObject( client );
+ }
+ iter->release();
+ }
+ }
+ victim->release();
+ victim = (IOService *) makeInactive->getObject(0);
+ if( victim) {
+ victim->retain();
+ makeInactive->removeObject(0);
+ }
}
+
+ makeInactive->release();
+
+ if( startPhase2)
+ scheduleTerminatePhase2( options );
+
+ return( true );
}
-bool IOService::terminate( IOOptionBits options = 0 )
+void IOService::scheduleTerminatePhase2( IOOptionBits options )
{
- bool ok;
- bool wasClosed;
- bool madeInactive;
- TerminateClientsContext context;
+ AbsoluteTime deadline;
+ int waitResult = THREAD_AWAKENED;
+ bool wait, haveDeadline = false;
- if( false == lockForArbitration( (options & kIOServiceRequired) ))
- return false;
+ options |= kIOServiceRequired;
retain();
- context.provider = this;
- context.options = options;
-
- ok = (options & kIOServiceRequired);
- wasClosed = (false == handleIsOpen( 0 ));
- if( !ok)
- ok = wasClosed;
-
- if( !ok) {
- applyToClients( &terminateRequestClose, (void *) &context );
- wasClosed = (false == handleIsOpen( 0 ));
- ok = wasClosed;
- }
+ IOLockLock( gJobsLock );
- if( ok) {
- madeInactive = (0 == (__state[0] & kIOServiceInactiveState));
- if( madeInactive) {
- __state[0] |= kIOServiceInactiveState;
- __state[0] &= ~(kIOServiceRegisteredState | kIOServiceMatchedState);
- if( 0 == (options & kIOServiceRecursing))
- __state[1] |= kIOServiceTerminatedState;
- }
- } else
- madeInactive = false;
+ if( (options & kIOServiceSynchronous)
+ && (current_thread() != gIOTerminateThread)) {
- unlockForArbitration();
+ do {
+ wait = (gIOTerminateThread != 0);
+ if( wait) {
+ // wait to become the terminate thread
+ IOLockSleep( gJobsLock, &gIOTerminateThread, THREAD_UNINT);
+ }
+ } while( wait );
- if( madeInactive) {
+ gIOTerminateThread = current_thread();
+ gIOTerminatePhase2List->setObject( this );
+ gIOTerminateWork++;
- adjustBusy( 1 );
- applyToInterested( gIOGeneralInterest,
- &terminateInterestApplier, (void *) &context );
+ do {
+ while( gIOTerminateWork )
+ terminateWorker( options );
+ wait = (0 != (__state[1] & kIOServiceBusyStateMask));
+ if( wait) {
+ // wait for the victim to go non-busy
+ if( !haveDeadline) {
+ clock_interval_to_deadline( 15, kSecondScale, &deadline );
+ haveDeadline = true;
+ }
+ waitResult = IOLockSleepDeadline( gJobsLock, &gIOTerminateWork,
+ deadline, THREAD_UNINT );
+ if( waitResult == THREAD_TIMED_OUT) {
+ IOLog("%s::terminate(kIOServiceSynchronous) timeout\n", getName());
+ }
+ }
+ } while(gIOTerminateWork || (wait && (waitResult != THREAD_TIMED_OUT)));
- deliverNotification( gIOTerminatedNotification, 0, 0xffffffff );
+ gIOTerminateThread = 0;
+ IOLockWakeup( gJobsLock, (event_t) &gIOTerminateThread, /* one-thread */ false);
- applyToClients( &terminateClientsApplier, (void *) &context );
+ } else {
+ // ! kIOServiceSynchronous
- if( wasClosed && (0 == (options & kIOServiceRecursing))) {
- if( options & kIOServiceSynchronous)
- doServiceTerminate( 0 );
+ gIOTerminatePhase2List->setObject( this );
+ if( 0 == gIOTerminateWork++) {
+ if( !gIOTerminateThread)
+ kernel_thread_start(&terminateThread, (void *) options, &gIOTerminateThread);
else
- ok = (0 != _IOServiceJob::startJob( this, kTerminateNubJob, 0 ));
+ IOLockWakeup(gJobsLock, (event_t) &gIOTerminateWork, /* one-thread */ false );
}
- if( options & kIOServiceSynchronous)
- waitQuiet();
}
- release();
+ IOLockUnlock( gJobsLock );
- return( ok );
+ release();
}
-void IOService::doServiceTerminate( IOOptionBits options )
+void IOService::terminateThread( void * arg, wait_result_t waitResult )
{
- IOService * next;
- OSIterator * iter;
- IOService * client;
- OSArray * deathList = 0;
- unsigned int index;
- bool finalize;
- bool ok = true;
-
- next = this;
- deathList = OSArray::withObjects( & (const OSObject *) next, 1, 1 );
- assert( deathList );
- if( !deathList)
- return;
+ IOLockLock( gJobsLock );
- index = 0;
- do {
- iter = next->getClientIterator();
- assert( iter );
- if( iter) {
+ while (gIOTerminateWork)
+ terminateWorker( (uintptr_t) arg );
- while( (client = (IOService *) iter->getNextObject())) {
+ thread_deallocate(gIOTerminateThread);
+ gIOTerminateThread = 0;
+ IOLockWakeup( gJobsLock, (event_t) &gIOTerminateThread, /* one-thread */ false);
- if( gIOKitDebug & kIOLogYield)
- LOG("%s::actionClients(%s)\n",
- next->getName(), client->getName());
+ IOLockUnlock( gJobsLock );
+}
- client->stop( next );
+void IOService::scheduleStop( IOService * provider )
+{
+ TLOG("%s::scheduleStop(%s)\n", getName(), provider->getName());
- if( next->isOpen( client ))
- next->close( client );
+ uint64_t regID1 = getRegistryEntryID();
+ uint64_t regID2 = provider->getRegistryEntryID();
+ IOServiceTrace(
+ IOSERVICE_TERMINATE_SCHEDULE_STOP,
+ (uintptr_t) regID1,
+ (uintptr_t) (regID1 >> 32),
+ (uintptr_t) regID2,
+ (uintptr_t) (regID2 >> 32));
- client->detach( next );
+ IOLockLock( gJobsLock );
+ gIOStopList->tailQ( this );
+ gIOStopProviderList->tailQ( provider );
- client->lockForArbitration();
- if( (client->__state[0] & kIOServiceInactiveState)
- && (0 == (client->__state[1] & kIOServiceTerminatedState))
- && (0 == client->getProvider()) ) {
- client->__state[1] |= kIOServiceTerminatedState;
- finalize = (false == client->handleIsOpen( 0 ));
- } else
- finalize = false;
- client->unlockForArbitration();
+ if( 0 == gIOTerminateWork++) {
+ if( !gIOTerminateThread)
+ kernel_thread_start(&terminateThread, (void *) 0, &gIOTerminateThread);
+ else
+ IOLockWakeup(gJobsLock, (event_t) &gIOTerminateWork, /* one-thread */ false );
+ }
- if( finalize)
- deathList->setObject( client );
- }
- iter->release();
- }
+ IOLockUnlock( gJobsLock );
+}
- } while( (next = (IOService *) deathList->getObject( ++index )) );
+void IOService::scheduleFinalize( void )
+{
+ TLOG("%s::scheduleFinalize\n", getName());
- while( index--) {
+ uint64_t regID1 = getRegistryEntryID();
+ IOServiceTrace(
+ IOSERVICE_TERMINATE_SCHEDULE_FINALIZE,
+ (uintptr_t) regID1,
+ (uintptr_t) (regID1 >> 32),
+ 0, 0);
- next = (IOService *) deathList->getObject( index );
- assert( next );
- next->retain();
- deathList->removeObject( index );
+ IOLockLock( gJobsLock );
+ gIOFinalizeList->tailQ( this );
- IOUserClient::destroyUserReferences( next );
+ if( 0 == gIOTerminateWork++) {
+ if( !gIOTerminateThread)
+ kernel_thread_start(&terminateThread, (void *) 0, &gIOTerminateThread);
+ else
+ IOLockWakeup(gJobsLock, (event_t) &gIOTerminateWork, /* one-thread */ false );
+ }
- next->unregisterAllInterest();
+ IOLockUnlock( gJobsLock );
+}
- ok = next->finalize( options );
- assert( ok );
+bool IOService::willTerminate( IOService * provider, IOOptionBits options )
+{
+ return( true );
+}
- if( gIOKitDebug & kIOLogYield)
- LOG("%s __state = %08lx:%08lx\n", next->getName(),
- next->__state[0], next->__state[1]);
- next->adjustBusy( -1 );
+bool IOService::didTerminate( IOService * provider, IOOptionBits options, bool * defer )
+{
+ if( false == *defer) {
- next->release();
+ if( lockForArbitration( true )) {
+ if( false == provider->handleIsOpen( this ))
+ scheduleStop( provider );
+ // -- compat
+ else {
+ message( kIOMessageServiceIsRequestingClose, provider, (void *) options );
+ if( false == provider->handleIsOpen( this ))
+ scheduleStop( provider );
+ }
+ // --
+ unlockForArbitration();
+ }
}
- deathList->release();
+ return( true );
}
-bool IOService::finalize( IOOptionBits options )
+void IOService::actionWillTerminate( IOService * victim, IOOptionBits options,
+ OSArray * doPhase2List )
{
- OSIterator * iter;
- IOService * provider;
-
- iter = getProviderIterator();
- assert( iter );
+ OSIterator * iter;
+ IOService * client;
+ bool ok;
+ iter = victim->getClientIterator();
if( iter) {
- while( (provider = (IOService *) iter->getNextObject())) {
- /* we come down here on programmatic terminate */
- stop( provider );
- if( provider->isOpen( this ))
- provider->close( this );
- detach( provider );
- }
- iter->release();
+ while( (client = (IOService *) iter->getNextObject())) {
+ TLOG("%s::willTerminate(%s, %08llx)\n",
+ client->getName(), victim->getName(), (long long)options);
+
+ uint64_t regID1 = client->getRegistryEntryID();
+ uint64_t regID2 = victim->getRegistryEntryID();
+ IOServiceTrace(
+ IOSERVICE_TERMINATE_WILL,
+ (uintptr_t) regID1,
+ (uintptr_t) (regID1 >> 32),
+ (uintptr_t) regID2,
+ (uintptr_t) (regID2 >> 32));
+
+ ok = client->willTerminate( victim, options );
+ doPhase2List->tailQ( client );
+ }
+ iter->release();
+ }
+}
+
+void IOService::actionDidTerminate( IOService * victim, IOOptionBits options )
+{
+ OSIterator * iter;
+ IOService * client;
+ bool defer = false;
+
+ victim->messageClients( kIOMessageServiceIsTerminated, (void *) options );
+
+ iter = victim->getClientIterator();
+ if( iter) {
+ while( (client = (IOService *) iter->getNextObject())) {
+ TLOG("%s::didTerminate(%s, %08llx)\n",
+ client->getName(), victim->getName(), (long long)options);
+ client->didTerminate( victim, options, &defer );
+
+ uint64_t regID1 = client->getRegistryEntryID();
+ uint64_t regID2 = victim->getRegistryEntryID();
+ IOServiceTrace(
+ (defer ? IOSERVICE_TERMINATE_DID_DEFER
+ : IOSERVICE_TERMINATE_DID),
+ (uintptr_t) regID1,
+ (uintptr_t) (regID1 >> 32),
+ (uintptr_t) regID2,
+ (uintptr_t) (regID2 >> 32));
+
+ TLOG("%s::didTerminate(%s, defer %d)\n",
+ client->getName(), victim->getName(), defer);
+ }
+ iter->release();
+ }
+}
+
+void IOService::actionFinalize( IOService * victim, IOOptionBits options )
+{
+ TLOG("%s::finalize(%08llx)\n", victim->getName(), (long long)options);
+
+ uint64_t regID1 = victim->getRegistryEntryID();
+ IOServiceTrace(
+ IOSERVICE_TERMINATE_FINALIZE,
+ (uintptr_t) regID1,
+ (uintptr_t) (regID1 >> 32),
+ 0, 0);
+
+ victim->finalize( options );
+}
+
+void IOService::actionStop( IOService * provider, IOService * client )
+{
+ TLOG("%s::stop(%s)\n", client->getName(), provider->getName());
+
+ uint64_t regID1 = provider->getRegistryEntryID();
+ uint64_t regID2 = client->getRegistryEntryID();
+ IOServiceTrace(
+ IOSERVICE_TERMINATE_STOP,
+ (uintptr_t) regID1,
+ (uintptr_t) (regID1 >> 32),
+ (uintptr_t) regID2,
+ (uintptr_t) (regID2 >> 32));
+
+ client->stop( provider );
+ if( provider->isOpen( client ))
+ provider->close( client );
+ TLOG("%s::detach(%s)\n", client->getName(), provider->getName());
+ client->detach( provider );
+}
+
+void IOService::terminateWorker( IOOptionBits options )
+{
+ OSArray * doPhase2List;
+ OSArray * didPhase2List;
+ OSSet * freeList;
+ UInt32 workDone;
+ IOService * victim;
+ IOService * client;
+ IOService * provider;
+ unsigned int idx;
+ bool moreToDo;
+ bool doPhase2;
+ bool doPhase3;
+
+ options |= kIOServiceRequired;
+
+ doPhase2List = OSArray::withCapacity( 16 );
+ didPhase2List = OSArray::withCapacity( 16 );
+ freeList = OSSet::withCapacity( 16 );
+ if( (0 == doPhase2List) || (0 == didPhase2List) || (0 == freeList))
+ return;
+
+ do {
+ workDone = gIOTerminateWork;
+
+ while( (victim = (IOService *) gIOTerminatePhase2List->getObject(0) )) {
+
+ victim->retain();
+ gIOTerminatePhase2List->removeObject(0);
+ IOLockUnlock( gJobsLock );
+
+ while( victim ) {
+
+ doPhase2 = victim->lockForArbitration( true );
+ if( doPhase2) {
+ doPhase2 = (0 != (kIOServiceInactiveState & victim->__state[0]));
+ if( doPhase2) {
+ doPhase2 = (0 == (victim->__state[1] & kIOServiceTermPhase2State))
+ && (0 == (victim->__state[1] & kIOServiceConfigState));
+ if( doPhase2)
+ victim->__state[1] |= kIOServiceTermPhase2State;
+ }
+ victim->unlockForArbitration();
+ }
+ if( doPhase2) {
+ if( 0 == victim->getClient()) {
+ // no clients - will go to finalize
+ IOLockLock( gJobsLock );
+ gIOFinalizeList->tailQ( victim );
+ IOLockUnlock( gJobsLock );
+ } else {
+ _workLoopAction( (IOWorkLoop::Action) &actionWillTerminate,
+ victim, (void *) options, (void *) doPhase2List );
+ }
+ didPhase2List->headQ( victim );
+ }
+ victim->release();
+ victim = (IOService *) doPhase2List->getObject(0);
+ if( victim) {
+ victim->retain();
+ doPhase2List->removeObject(0);
+ }
+ }
+
+ while( (victim = (IOService *) didPhase2List->getObject(0)) ) {
+
+ if( victim->lockForArbitration( true )) {
+ victim->__state[1] |= kIOServiceTermPhase3State;
+ victim->unlockForArbitration();
+ }
+ _workLoopAction( (IOWorkLoop::Action) &actionDidTerminate,
+ victim, (void *) options );
+ didPhase2List->removeObject(0);
+ }
+ IOLockLock( gJobsLock );
+ }
+
+ // phase 3
+ do {
+ doPhase3 = false;
+ // finalize leaves
+ while( (victim = (IOService *) gIOFinalizeList->getObject(0))) {
+
+ IOLockUnlock( gJobsLock );
+ _workLoopAction( (IOWorkLoop::Action) &actionFinalize,
+ victim, (void *) options );
+ IOLockLock( gJobsLock );
+ // hold off free
+ freeList->setObject( victim );
+ // safe if finalize list is append only
+ gIOFinalizeList->removeObject(0);
+ }
+
+ for( idx = 0;
+ (!doPhase3) && (client = (IOService *) gIOStopList->getObject(idx)); ) {
+
+ provider = (IOService *) gIOStopProviderList->getObject(idx);
+ assert( provider );
+
+ if( !provider->isChild( client, gIOServicePlane )) {
+ // may be multiply queued - nop it
+ TLOG("%s::nop stop(%s)\n", client->getName(), provider->getName());
+
+ uint64_t regID1 = provider->getRegistryEntryID();
+ uint64_t regID2 = client->getRegistryEntryID();
+ IOServiceTrace(
+ IOSERVICE_TERMINATE_STOP_NOP,
+ (uintptr_t) regID1,
+ (uintptr_t) (regID1 >> 32),
+ (uintptr_t) regID2,
+ (uintptr_t) (regID2 >> 32));
+
+ } else {
+ // not ready for stop if it has clients, skip it
+ if( (client->__state[1] & kIOServiceTermPhase3State) && client->getClient()) {
+ TLOG("%s::defer stop(%s)\n", client->getName(), provider->getName());
+
+ uint64_t regID1 = provider->getRegistryEntryID();
+ uint64_t regID2 = client->getRegistryEntryID();
+ IOServiceTrace(
+ IOSERVICE_TERMINATE_STOP_DEFER,
+ (uintptr_t) regID1,
+ (uintptr_t) (regID1 >> 32),
+ (uintptr_t) regID2,
+ (uintptr_t) (regID2 >> 32));
+
+ idx++;
+ continue;
+ }
+
+ IOLockUnlock( gJobsLock );
+ _workLoopAction( (IOWorkLoop::Action) &actionStop,
+ provider, (void *) client );
+ IOLockLock( gJobsLock );
+ // check the finalize list now
+ doPhase3 = true;
+ }
+ // hold off free
+ freeList->setObject( client );
+ freeList->setObject( provider );
+
+ // safe if stop list is append only
+ gIOStopList->removeObject( idx );
+ gIOStopProviderList->removeObject( idx );
+ idx = 0;
+ }
+
+ } while( doPhase3 );
+
+ gIOTerminateWork -= workDone;
+ moreToDo = (gIOTerminateWork != 0);
+
+ if( !moreToDo) {
+ TLOG("iokit terminate done, %d stops remain\n", gIOStopList->getCount());
+ IOServiceTrace(
+ IOSERVICE_TERMINATE_DONE,
+ (uintptr_t) gIOStopList->getCount(), 0, 0, 0);
+ }
+
+ } while( moreToDo );
+
+ IOLockUnlock( gJobsLock );
+
+ freeList->release();
+ doPhase2List->release();
+ didPhase2List->release();
+
+ IOLockLock( gJobsLock );
+}
+
+bool IOService::finalize( IOOptionBits options )
+{
+ OSIterator * iter;
+ IOService * provider;
+
+ iter = getProviderIterator();
+ assert( iter );
+
+ if( iter) {
+ while( (provider = (IOService *) iter->getNextObject())) {
+
+ // -- compat
+ if( 0 == (__state[1] & kIOServiceTermPhase3State)) {
+ /* we come down here on programmatic terminate */
+ stop( provider );
+ if( provider->isOpen( this ))
+ provider->close( this );
+ detach( provider );
+ } else {
+ //--
+ if( provider->lockForArbitration( true )) {
+ if( 0 == (provider->__state[1] & kIOServiceTermPhase3State))
+ scheduleStop( provider );
+ provider->unlockForArbitration();
+ }
+ }
+ }
+ iter->release();
}
return( true );
}
+#undef tailQ
+#undef headQ
+
+/*
+ * Terminate
+ */
+
+void IOService::doServiceTerminate( IOOptionBits options )
+{
+}
+
+// a method in case someone needs to override it
+bool IOService::terminateClient( IOService * client, IOOptionBits options )
+{
+ bool ok;
+
+ if( client->isParent( this, gIOServicePlane, true))
+ // we are the clients only provider
+ ok = client->terminate( options );
+ else
+ ok = true;
+
+ return( ok );
+}
+
+bool IOService::terminate( IOOptionBits options )
+{
+ options |= kIOServiceTerminate;
+
+ return( terminatePhase1( options ));
+}
+
+/* * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * * */
+
/*
* Open & close
*/
+struct ServiceOpenMessageContext
+{
+ IOService * service;
+ UInt32 type;
+ IOService * excludeClient;
+ IOOptionBits options;
+};
+
+static void serviceOpenMessageApplier( OSObject * object, void * ctx )
+{
+ ServiceOpenMessageContext * context = (ServiceOpenMessageContext *) ctx;
+
+ if( object != context->excludeClient)
+ context->service->messageClient( context->type, object, (void *) context->options );
+}
+
bool IOService::open( IOService * forClient,
- IOOptionBits options = 0,
- void * arg = 0 )
+ IOOptionBits options,
+ void * arg )
{
- bool ok;
+ bool ok;
+ ServiceOpenMessageContext context;
+
+ context.service = this;
+ context.type = kIOMessageServiceIsAttemptingOpen;
+ context.excludeClient = forClient;
+ context.options = options;
+
+ applyToInterested( gIOGeneralInterest,
+ &serviceOpenMessageApplier, &context );
if( false == lockForArbitration(false) )
return false;
}
void IOService::close( IOService * forClient,
- IOOptionBits options = 0 )
+ IOOptionBits options )
{
- bool ok;
bool wasClosed;
bool last = false;
- OSIterator * iter;
- IOService * client;
lockForArbitration();
wasClosed = handleIsOpen( forClient );
if( wasClosed) {
handleClose( forClient, options );
-
- last = ( (__state[1] & kIOServiceTerminatedState)
- && (false == handleIsOpen( 0 )) );
+ last = (__state[1] & kIOServiceTermPhase3State);
}
unlockForArbitration();
- if( last) {
- ok = (0 != _IOServiceJob::startJob( this, kTerminateNubJob, 0 ));
- assert( ok );
+ if( last)
+ forClient->scheduleStop( this );
- } else if( wasClosed) {
+ else if( wasClosed) {
- iter = getClientIterator();
- assert( iter );
+ ServiceOpenMessageContext context;
+
+ context.service = this;
+ context.type = kIOMessageServiceWasClosed;
+ context.excludeClient = forClient;
+ context.options = options;
- if( iter) {
- while( (client = (IOService *) iter->getNextObject())) {
- if( client != forClient)
- messageClient( kIOMessageServiceWasClosed, client, 0 );
- }
- iter->release();
- }
+ applyToInterested( gIOGeneralInterest,
+ &serviceOpenMessageApplier, &context );
}
}
-bool IOService::isOpen( const IOService * forClient = 0 ) const
+bool IOService::isOpen( const IOService * forClient ) const
{
IOService * self = (IOService *) this;
bool ok;
else if( options & kIOServiceSeize ) {
ok = (kIOReturnSuccess == messageClient( kIOMessageServiceIsRequestingClose,
- __owner, (void *) options ));
- if( ok && (0 == __owner ))
+ __owner, (void *) options ));
+ if( ok && (0 == __owner ))
__owner = forClient;
+ else
+ ok = false;
}
-
return( ok );
}
return ( val1 - val2 );
}
-IOService * IOService::getClientWithCategory( const OSSymbol * category )
+IOService * IOService::copyClientWithCategory( const OSSymbol * category )
{
IOService * service = 0;
OSIterator * iter;
nextCat = (const OSSymbol *) OSDynamicCast( OSSymbol,
service->getProperty( gIOMatchCategoryKey ));
if( category == nextCat)
+ {
+ service->retain();
break;
+ }
}
iter->release();
}
return( service );
}
+IOService * IOService::getClientWithCategory( const OSSymbol * category )
+{
+ IOService *
+ service = copyClientWithCategory(category);
+ if (service)
+ service->release();
+ return (service);
+}
+
bool IOService::invokeNotifer( _IOServiceNotifier * notify )
{
_IOServiceNotifierInvocation invocation;
if( willNotify) {
- ret = (*notify->handler)( notify->target, notify->ref, this );
+ ret = (*notify->handler)(notify->target, notify->ref, this, notify);
LOCKWRITENOTIFY();
queue_remove( ¬ify->handlerInvocations, &invocation,
_IOServiceNotifierInvocation *, link );
if( kIOServiceNotifyWaiter & notify->state) {
notify->state &= ~kIOServiceNotifyWaiter;
- thread_wakeup( (event_t) notify);
+ WAKEUPNOTIFY( notify );
}
UNLOCKNOTIFY();
}
OSObject * nextMatch = 0;
bool started;
bool needReloc = false;
+#if CONFIG_MACF_KEXT
+ OSBoolean * isSandbox = 0;
+ bool useSandbox = false;
+#endif
#if IOMATCHDEBUG
SInt64 debugFlags;
#endif
+ IOService * client = NULL;
+
assert( matches );
while( !needReloc && (nextMatch = matches->getFirstObject())) {
match->getObject( gIOMatchCategoryKey ));
if( 0 == category)
category = gIODefaultMatchCategoryKey;
-
- if( getClientWithCategory( category )) {
+
+ if( (client = copyClientWithCategory(category)) ) {
#if IOMATCHDEBUG
if( debugFlags & kIOLogMatch)
LOG("%s: match category %s exists\n", getName(),
#endif
nextMatch->release();
nextMatch = 0;
+
+ client->release();
+ client = NULL;
+
continue;
}
if( !symbol)
continue;
+ //IOLog("%s alloc (symbol %p props %p)\n", symbol->getCStringNoCopy(), symbol, props);
+
// alloc the driver instance
inst = (IOService *) OSMetaClass::allocClassWithName( symbol);
if( 0 == category)
category = gIODefaultMatchCategoryKey;
inst->setProperty( gIOMatchCategoryKey, (OSObject *) category );
-
+#if CONFIG_MACF_KEXT
+ isSandbox = OSDynamicCast(OSBoolean,
+ props->getObject("IOKitForceMatch"));
+#endif
// attach driver instance
if( !(inst->attach( this )))
continue;
newInst = inst->probe( this, &score );
inst->detach( this );
+#if CONFIG_MACF_KEXT
+ /*
+ * If this is the Sandbox driver and it matched, this is a
+ * disallowed device; toss any drivers that were already
+ * matched.
+ */
+ if (isSandbox && isSandbox->isTrue() && newInst != 0) {
+ if (startDict != 0) {
+ startDict->flushCollection();
+ startDict->release();
+ startDict = 0;
+ }
+ useSandbox = true;
+ }
+#endif
if( 0 == newInst) {
#if IOMATCHDEBUG
if( debugFlags & kIOLogProbe)
props->release();
if( inst)
inst->release();
+#if CONFIG_MACF_KEXT
+ /*
+ * If we're forcing the sandbox, drop out of the loop.
+ */
+ if (isSandbox && isSandbox->isTrue() && useSandbox)
+ break;
+#endif
}
familyMatches->release();
familyMatches = 0;
iter->release();
}
+
+ // adjust the busy count by +1 if matching is stalled for a module,
+ // or -1 if a previously stalled matching is complete.
+ lockForArbitration();
+ SInt32 adjBusy = 0;
+ uint64_t regID = getRegistryEntryID();
+
+ if( needReloc) {
+ adjBusy = (__state[1] & kIOServiceModuleStallState) ? 0 : 1;
+ if( adjBusy) {
+
+ IOServiceTrace(
+ IOSERVICE_MODULESTALL,
+ (uintptr_t) regID,
+ (uintptr_t) (regID >> 32),
+ (uintptr_t) this,
+ 0);
+
+ __state[1] |= kIOServiceModuleStallState;
+ }
+
+ } else if( __state[1] & kIOServiceModuleStallState) {
+
+ IOServiceTrace(
+ IOSERVICE_MODULEUNSTALL,
+ (uintptr_t) regID,
+ (uintptr_t) (regID >> 32),
+ (uintptr_t) this,
+ 0);
+
+ __state[1] &= ~kIOServiceModuleStallState;
+ adjBusy = -1;
+ }
+ if( adjBusy)
+ _adjustBusy( adjBusy );
+ unlockForArbitration();
+
if( startDict)
startDict->release();
}
ok = service->attach( this );
- if( ok) {
- // stall for any nub resources
- checkResources();
- // stall for any driver resources
- service->checkResources();
+ if( ok)
+ {
+ if (this != gIOResources)
+ {
+ // stall for any nub resources
+ checkResources();
+ // stall for any driver resources
+ service->checkResources();
+ }
+
+ AbsoluteTime startTime;
+ AbsoluteTime endTime;
+ UInt64 nano;
+
+ if (kIOLogStart & gIOKitDebug)
+ clock_get_uptime(&startTime);
- ok = service->start( this );
+ ok = service->start(this);
+
+ if (kIOLogStart & gIOKitDebug)
+ {
+ clock_get_uptime(&endTime);
+
+ if (CMP_ABSOLUTETIME(&endTime, &startTime) > 0)
+ {
+ SUB_ABSOLUTETIME(&endTime, &startTime);
+ absolutetime_to_nanoseconds(endTime, &nano);
+ if (nano > 500000000ULL)
+ IOLog("%s::start took %ld ms\n", service->getName(), (long)(UInt32)(nano / 1000000ULL));
+ }
+ }
if( !ok)
service->detach( this );
}
return( ok );
}
-IOService * IOService::resources( void )
-{
- return( gIOResources );
-}
-
-void IOService::publishResource( const char * key, OSObject * value = 0 )
+void IOService::publishResource( const char * key, OSObject * value )
{
const OSSymbol * sym;
}
}
-void IOService::publishResource( const OSSymbol * key, OSObject * value = 0 )
+void IOService::publishResource( const OSSymbol * key, OSObject * value )
{
if( 0 == value)
value = (OSObject *) gIOServiceKey;
gIOResources->setProperty( key, value);
+ if( IORecursiveLockHaveLock( gNotificationLock))
+ return;
+
gIOResourceGenerationCount++;
gIOResources->registerService();
}
bool IOService::addNeededResource( const char * key )
{
- OSObject * resources;
+ OSObject * resourcesProp;
OSSet * set;
OSString * newKey;
bool ret;
- resources = getProperty( gIOResourceMatchKey );
+ resourcesProp = getProperty( gIOResourceMatchKey );
newKey = OSString::withCString( key );
- if( (0 == resources) || (0 == newKey))
+ if( (0 == resourcesProp) || (0 == newKey))
return( false);
- set = OSDynamicCast( OSSet, resources );
+ set = OSDynamicCast( OSSet, resourcesProp );
if( !set) {
set = OSSet::withCapacity( 1 );
if( set)
- set->setObject( resources );
+ set->setObject( resourcesProp );
}
else
set->retain();
}
if( gIOKitDebug & kIOLogConfig)
- LOG("config(%x): stalling %s\n", (int) IOThreadSelf(), getName());
+ LOG("config(%p): stalling %s\n", IOThreadSelf(), getName());
waitForService( table );
if( gIOKitDebug & kIOLogConfig)
- LOG("config(%x): waking\n", (int) IOThreadSelf() );
+ LOG("config(%p): waking\n", IOThreadSelf() );
return( true );
}
bool IOService::checkResources( void )
{
- OSObject * resources;
+ OSObject * resourcesProp;
OSSet * set;
OSIterator * iter;
bool ok;
- resources = getProperty( gIOResourceMatchKey );
- if( 0 == resources)
+ resourcesProp = getProperty( gIOResourceMatchKey );
+ if( 0 == resourcesProp)
return( true );
- if( (set = OSDynamicCast( OSSet, resources ))) {
+ if( (set = OSDynamicCast( OSSet, resourcesProp ))) {
iter = OSCollectionIterator::withCollection( set );
ok = (0 != iter);
- while( ok && (resources = iter->getNextObject()) )
- ok = checkResource( resources );
+ while( ok && (resourcesProp = iter->getNextObject()) )
+ ok = checkResource( resourcesProp );
if( iter)
iter->release();
} else
- ok = checkResource( resources );
+ ok = checkResource( resourcesProp );
return( ok );
}
-_IOConfigThread * _IOConfigThread::configThread( void )
+void _IOConfigThread::configThread( void )
{
_IOConfigThread * inst;
continue;
if( !inst->init())
continue;
- if( !(inst->thread = IOCreateThread
- ( (IOThreadFunc) &_IOConfigThread::main, inst )))
+ thread_t unused;
+ if (KERN_SUCCESS != kernel_thread_start(&_IOConfigThread::main, inst, &unused))
continue;
- return( inst );
+ return;
} while( false);
if( inst)
inst->release();
- return( 0 );
+ return;
}
void _IOConfigThread::free( void )
{
+ thread_deallocate(current_thread());
OSObject::free();
}
deliverNotification( gIOFirstPublishNotification,
kIOServiceFirstPublishState, 0xffffffff );
LOCKREADNOTIFY();
- __state[1] &= ~kIOServiceConfigState;
+ __state[1] &= ~kIOServiceNeedConfigState;
+ __state[1] |= kIOServiceConfigState;
__state[0] |= kIOServiceRegisteredState;
if( reRegistered && (0 == (__state[0] & kIOServiceInactiveState))) {
}
lockForArbitration();
- reRegistered = (0 != (__state[1] & kIOServiceConfigState));
+ reRegistered = (0 != (__state[1] & kIOServiceNeedConfigState));
keepGuessing =
(reRegistered || (catalogGeneration !=
gIOCatalogue->getGenerationCount()))
unlockForArbitration();
}
- if( 0 == (__state[0] & kIOServiceInactiveState)) {
+ if( (0 == (__state[0] & kIOServiceInactiveState))
+ && (0 == (__state[1] & kIOServiceModuleStallState)) ) {
deliverNotification( gIOMatchedNotification,
kIOServiceMatchedState, 0xffffffff );
if( 0 == (__state[0] & kIOServiceFirstMatchState))
kIOServiceFirstMatchState, 0xffffffff );
}
- unlockForArbitration();
+ __state[1] &= ~kIOServiceConfigState;
+ if( __state[0] & kIOServiceInactiveState)
+ scheduleTerminatePhase2();
- adjustBusy( -1 );
+ _adjustBusy( -1 );
+ unlockForArbitration();
}
-void IOService::adjustBusy( SInt32 delta )
+UInt32 IOService::_adjustBusy( SInt32 delta )
{
IOService * next;
UInt32 count;
- bool wasQuiet, nowQuiet;
+ UInt32 result;
+ bool wasQuiet, nowQuiet, needWake;
- if( 0 == delta)
- return;
-
- IOTakeLock( gIOServiceBusyLock );
next = this;
+ result = __state[1] & kIOServiceBusyStateMask;
- do {
+ if( delta) do {
+ if( next != this)
+ next->lockForArbitration();
count = next->__state[1] & kIOServiceBusyStateMask;
- assert( count < kIOServiceBusyMax);
wasQuiet = (0 == count);
- assert( (!wasQuiet) || (delta > 0));
- next->__state[1] += delta;
- nowQuiet = (0 == (next->__state[1] & kIOServiceBusyStateMask));
-
- if( nowQuiet)
+ if (((delta < 0) && wasQuiet) || ((delta > 0) && (kIOServiceBusyMax == count)))
+ OSReportWithBacktrace("%s: bad busy count (%d,%d)\n", next->getName(), count, delta);
+ else
+ count += delta;
+ next->__state[1] = (next->__state[1] & ~kIOServiceBusyStateMask) | count;
+ nowQuiet = (0 == count);
+ needWake = (0 != (kIOServiceBusyWaiterState & next->__state[1]));
+
+ if( needWake) {
+ next->__state[1] &= ~kIOServiceBusyWaiterState;
+ IOLockLock( gIOServiceBusyLock );
thread_wakeup( (event_t) next);
+ IOLockUnlock( gIOServiceBusyLock );
+ }
+ if( next != this)
+ next->unlockForArbitration();
if( (wasQuiet || nowQuiet) ) {
- OSArray * array;
- unsigned int index;
- OSObject * interested;
-
- array = OSDynamicCast( OSArray, next->getProperty( gIOBusyInterest ));
- if( array) {
- LOCKREADNOTIFY();
- for( index = 0;
- (interested = array->getObject( index ));
- index++) {
- next->messageClient(kIOMessageServiceBusyStateChange,
- interested, (void *) wasQuiet /* busy now */);
- }
- UNLOCKNOTIFY();
- }
+ uint64_t regID = next->getRegistryEntryID();
+
+ IOServiceTrace(
+ ((wasQuiet/*nowBusy*/) ? IOSERVICE_BUSY : IOSERVICE_NONBUSY),
+ (uintptr_t) regID,
+ (uintptr_t) (regID >> 32),
+ (uintptr_t) next,
+ 0);
+
+ if (wasQuiet)
+ {
+ next->__timeBusy = mach_absolute_time();
+ }
+ else
+ {
+ next->__accumBusy += mach_absolute_time() - next->__timeBusy;
+ next->__timeBusy = 0;
+ }
+
+ MessageClientsContext context;
+
+ context.service = next;
+ context.type = kIOMessageServiceBusyStateChange;
+ context.argument = (void *) wasQuiet; /*nowBusy*/
+ context.argSize = 0;
+
+ applyToInterestNotifiers( next, gIOBusyInterest,
+ &messageClientsApplier, &context );
+#if !NO_KEXTD
if( nowQuiet && (next == gIOServiceRoot))
- OSMetaClass::considerUnloads();
+ OSKext::considerUnloads();
+#endif
}
delta = nowQuiet ? -1 : +1;
} while( (wasQuiet || nowQuiet) && (next = next->getProvider()));
- IOUnlock( gIOServiceBusyLock );
+ return( result );
+}
+
+void IOService::adjustBusy( SInt32 delta )
+{
+ lockForArbitration();
+ _adjustBusy( delta );
+ unlockForArbitration();
+}
+
+uint64_t IOService::getAccumulatedBusyTime( void )
+{
+ uint64_t accumBusy = __accumBusy;
+ uint64_t timeBusy = __timeBusy;
+ uint64_t nano;
+
+ do
+ {
+ accumBusy = __accumBusy;
+ timeBusy = __timeBusy;
+ if (timeBusy)
+ accumBusy += mach_absolute_time() - timeBusy;
+ }
+ while (timeBusy != __timeBusy);
+
+ absolutetime_to_nanoseconds(*(AbsoluteTime *)&accumBusy, &nano);
+
+ return (nano);
}
UInt32 IOService::getBusyState( void )
}
IOReturn IOService::waitForState( UInt32 mask, UInt32 value,
- mach_timespec_t * timeout = 0 )
+ mach_timespec_t * timeout )
+{
+ panic("waitForState");
+ return (kIOReturnUnsupported);
+}
+
+IOReturn IOService::waitForState( UInt32 mask, UInt32 value,
+ uint64_t timeout )
{
bool wait;
int waitResult = THREAD_AWAKENED;
AbsoluteTime abstime;
do {
- IOTakeLock( gIOServiceBusyLock );
+ lockForArbitration();
+ IOLockLock( gIOServiceBusyLock );
wait = (value != (__state[1] & mask));
- if( wait)
- {
- assert_wait( (event_t) this, THREAD_UNINT );
- if ( timeout )
- {
- if ( computeDeadline )
- {
+ if( wait) {
+ __state[1] |= kIOServiceBusyWaiterState;
+ unlockForArbitration();
+ if( timeout != UINT64_MAX ) {
+ if( computeDeadline ) {
AbsoluteTime nsinterval;
- clock_interval_to_absolutetime_interval(
- timeout->tv_sec, kSecondScale, &abstime );
- clock_interval_to_absolutetime_interval(
- timeout->tv_nsec, kNanosecondScale, &nsinterval );
- ADD_ABSOLUTETIME( &abstime, &nsinterval );
- clock_absolutetime_interval_to_deadline(
- abstime, &abstime );
+ nanoseconds_to_absolutetime(timeout, &nsinterval );
+ clock_absolutetime_interval_to_deadline(nsinterval, &abstime);
computeDeadline = false;
}
- thread_set_timer_deadline( abstime );
+ assert_wait_deadline((event_t)this, THREAD_UNINT, __OSAbsoluteTime(abstime));
}
- }
- IOUnlock( gIOServiceBusyLock );
+ else
+ assert_wait((event_t)this, THREAD_UNINT );
+ } else
+ unlockForArbitration();
+ IOLockUnlock( gIOServiceBusyLock );
if( wait)
- {
- waitResult = thread_block((void (*)(void)) 0);
- if ( timeout && (waitResult != THREAD_TIMED_OUT))
- thread_cancel_timer();
- }
+ waitResult = thread_block(THREAD_CONTINUE_NULL);
- } while( wait && ( waitResult != THREAD_TIMED_OUT ) );
+ } while( wait && (waitResult != THREAD_TIMED_OUT));
- if ( waitResult == THREAD_TIMED_OUT )
+ if( waitResult == THREAD_TIMED_OUT)
return( kIOReturnTimeout );
else
return( kIOReturnSuccess );
}
-IOReturn IOService::waitQuiet( mach_timespec_t * timeout = 0 )
+IOReturn IOService::waitQuiet( uint64_t timeout )
{
return( waitForState( kIOServiceBusyStateMask, 0, timeout ));
}
+IOReturn IOService::waitQuiet( mach_timespec_t * timeout )
+{
+ uint64_t timeoutNS;
+
+ if (timeout)
+ {
+ timeoutNS = timeout->tv_sec;
+ timeoutNS *= kSecondScale;
+ timeoutNS += timeout->tv_nsec;
+ }
+ else
+ timeoutNS = UINT64_MAX;
+
+ return( waitForState( kIOServiceBusyStateMask, 0, timeoutNS ));
+}
+
bool IOService::serializeProperties( OSSerialize * s ) const
{
#if 0
}
-void _IOConfigThread::main( _IOConfigThread * self )
+void _IOConfigThread::main(void * arg, wait_result_t result)
{
- _IOServiceJob * job;
- IOService * nub;
- bool alive = true;
+ _IOConfigThread * self = (_IOConfigThread *) arg;
+ _IOServiceJob * job;
+ IOService * nub;
+ bool alive = true;
+ kern_return_t kr;
+ thread_precedence_policy_data_t precedence = { -1 };
+
+ kr = thread_policy_set(current_thread(),
+ THREAD_PRECEDENCE_POLICY,
+ (thread_policy_t) &precedence,
+ THREAD_PRECEDENCE_POLICY_COUNT);
+ if (KERN_SUCCESS != kr)
+ IOLog("thread_policy_set(%d)\n", kr);
do {
-#if 0
-#define randomDelay() \
- int del = read_processor_clock(); \
- del = (((int)IOThreadSelf()) ^ del ^ (del >> 10)) & 0x3ff; \
- IOSleep( del );
- randomDelay();
-#endif
+// randomDelay();
semaphore_wait( gJobsSemaphore );
gJobs->removeObject(job);
if( job) {
gOutstandingJobs--;
-#ifndef LESS_THREAD_CREATE
// gNumConfigThreads--; // we're out of service
gNumWaitingThreads--; // we're out of service
-#endif
}
IOUnlock( gJobsLock );
nub = job->nub;
if( gIOKitDebug & kIOLogConfig)
- LOG("config(%x): starting on %s, %d\n",
- (int) IOThreadSelf(), job->nub->getName(), job->type);
+ LOG("config(%p): starting on %s, %d\n",
+ IOThreadSelf(), job->nub->getName(), job->type);
switch( job->type) {
nub->doServiceMatch( job->options );
break;
- case kTerminateNubJob:
- nub->doServiceTerminate( job->options );
- break;
-
default:
- LOG("config(%x): strange type (%d)\n",
- (int) IOThreadSelf(), job->type );
+ LOG("config(%p): strange type (%d)\n",
+ IOThreadSelf(), job->type );
break;
}
job->release();
IOTakeLock( gJobsLock );
-#ifndef LESS_THREAD_CREATE
alive = (gOutstandingJobs > gNumWaitingThreads);
if( alive)
gNumWaitingThreads++; // back in service
// gNumConfigThreads++;
- else
- gNumConfigThreads--;
-#endif
+ else {
+ if( 0 == --gNumConfigThreads) {
+// IOLog("MATCH IDLE\n");
+ IOLockWakeup( gJobsLock, (event_t) &gNumConfigThreads, /* one-thread */ false );
+ }
+ }
IOUnlock( gJobsLock );
}
} while( alive );
if( gIOKitDebug & kIOLogConfig)
- LOG("config(%x): terminating\n", (int) IOThreadSelf() );
+ LOG("config(%p): terminating\n", IOThreadSelf() );
self->release();
}
+IOReturn IOService::waitMatchIdle( UInt32 msToWait )
+{
+ bool wait;
+ int waitResult = THREAD_AWAKENED;
+ bool computeDeadline = true;
+ AbsoluteTime abstime;
+
+ IOLockLock( gJobsLock );
+ do {
+ wait = (0 != gNumConfigThreads);
+ if( wait) {
+ if( msToWait) {
+ if( computeDeadline ) {
+ clock_interval_to_absolutetime_interval(
+ msToWait, kMillisecondScale, &abstime );
+ clock_absolutetime_interval_to_deadline(
+ abstime, &abstime );
+ computeDeadline = false;
+ }
+ waitResult = IOLockSleepDeadline( gJobsLock, &gNumConfigThreads,
+ abstime, THREAD_UNINT );
+ } else {
+ waitResult = IOLockSleep( gJobsLock, &gNumConfigThreads,
+ THREAD_UNINT );
+ }
+ }
+ } while( wait && (waitResult != THREAD_TIMED_OUT));
+ IOLockUnlock( gJobsLock );
+
+ if( waitResult == THREAD_TIMED_OUT)
+ return( kIOReturnTimeout );
+ else
+ return( kIOReturnSuccess );
+}
+
void _IOServiceJob::pingConfig( _IOServiceJob * job )
{
int count;
semaphore_signal( gJobsSemaphore );
}
-
// internal - call with gNotificationLock
-OSObject * IOService::getExistingServices( OSDictionary * matching,
- IOOptionBits inState, IOOptionBits options = 0 )
+OSObject * IOService::copyExistingServices( OSDictionary * matching,
+ IOOptionBits inState, IOOptionBits options )
{
OSObject * current = 0;
OSIterator * iter;
IOService * service;
+ OSObject * obj;
if( !matching)
return( 0 );
- iter = IORegistryIterator::iterateOver( gIOServicePlane,
- kIORegistryIterateRecursively );
- if( iter) {
- do {
- iter->reset();
- while( (service = (IOService *) iter->getNextObject())) {
- if( (inState == (service->__state[0] & inState))
- && (0 == (service->__state[0] & kIOServiceInactiveState))
- && service->passiveMatch( matching )) {
-
- if( options & kIONotifyOnce) {
- current = service;
- break;
- }
- if( current)
- ((OSSet *)current)->setObject( service );
- else
- current = OSSet::withObjects(
- & (const OSObject *) service, 1, 1 );
- }
- }
- } while( !service && !iter->isValid());
- iter->release();
+ if(true
+ && (obj = matching->getObject(gIOProviderClassKey))
+ && gIOResourcesKey
+ && gIOResourcesKey->isEqualTo(obj)
+ && (service = gIOResources))
+ {
+ if( (inState == (service->__state[0] & inState))
+ && (0 == (service->__state[0] & kIOServiceInactiveState))
+ && service->passiveMatch( matching ))
+ {
+ if( options & kIONotifyOnce)
+ {
+ service->retain();
+ current = service;
+ }
+ else
+ current = OSSet::withObjects(
+ (const OSObject **) &service, 1, 1 );
+ }
+ }
+ else
+ {
+ iter = IORegistryIterator::iterateOver( gIOServicePlane,
+ kIORegistryIterateRecursively );
+ if( iter) {
+ do {
+ iter->reset();
+ while( (service = (IOService *) iter->getNextObject())) {
+ if( (inState == (service->__state[0] & inState))
+ && (0 == (service->__state[0] & kIOServiceInactiveState))
+ && service->passiveMatch( matching )) {
+
+ if( options & kIONotifyOnce) {
+ service->retain();
+ current = service;
+ break;
+ }
+ if( current)
+ ((OSSet *)current)->setObject( service );
+ else
+ current = OSSet::withObjects(
+ (const OSObject **) &service, 1, 1 );
+ }
+ }
+ } while( !service && !iter->isValid());
+ iter->release();
+ }
}
- if( current && (0 == (options & kIONotifyOnce))) {
+ if( current && (0 == (options & (kIONotifyOnce | kIOServiceExistingSet)))) {
iter = OSCollectionIterator::withCollection( (OSSet *)current );
current->release();
current = iter;
// is a lock even needed?
LOCKWRITENOTIFY();
- iter = (OSIterator *) getExistingServices( matching,
- kIOServiceRegisteredState );
+ iter = (OSIterator *) copyExistingServices( matching,
+ kIOServiceMatchedState );
UNLOCKNOTIFY();
return( iter );
}
+struct _IOServiceMatchingNotificationHandlerRef
+{
+ IOServiceNotificationHandler handler;
+ void * ref;
+};
+
+static bool _IOServiceMatchingNotificationHandler( void * target, void * refCon,
+ IOService * newService,
+ IONotifier * notifier )
+{
+ return ((*((_IOServiceNotifier *) notifier)->compatHandler)(target, refCon, newService));
+}
// internal - call with gNotificationLock
IONotifier * IOService::setNotification(
const OSSymbol * type, OSDictionary * matching,
- IOServiceNotificationHandler handler, void * target, void * ref,
- SInt32 priority = 0 )
+ IOServiceMatchingNotificationHandler handler, void * target, void * ref,
+ SInt32 priority )
{
_IOServiceNotifier * notify = 0;
OSOrderedSet * set;
}
if( notify) {
- notify->matching = matching;
- notify->handler = handler;
+ notify->handler = handler;
notify->target = target;
- notify->ref = ref;
+ notify->matching = matching;
+ matching->retain();
+ if (handler == &_IOServiceMatchingNotificationHandler)
+ {
+ notify->compatHandler = ((_IOServiceMatchingNotificationHandlerRef *)ref)->handler;
+ notify->ref = ((_IOServiceMatchingNotificationHandlerRef *)ref)->ref;
+ }
+ else
+ notify->ref = ref;
notify->priority = priority;
notify->state = kIOServiceNotifyEnable;
queue_init( ¬ify->handlerInvocations );
// internal - call with gNotificationLock
IONotifier * IOService::doInstallNotification(
const OSSymbol * type, OSDictionary * matching,
- IOServiceNotificationHandler handler,
+ IOServiceMatchingNotificationHandler handler,
void * target, void * ref,
SInt32 priority, OSIterator ** existing )
{
if( !matching)
return( 0 );
- if( (type == gIOPublishNotification)
- || (type == gIOFirstPublishNotification))
+ if( type == gIOPublishNotification)
inState = kIOServiceRegisteredState;
+
+ else if( type == gIOFirstPublishNotification)
+ inState = kIOServiceFirstPublishState;
+
else if( (type == gIOMatchedNotification)
|| (type == gIOFirstMatchNotification))
inState = kIOServiceMatchedState;
if( inState)
// get the current set
- exist = (OSIterator *) getExistingServices( matching, inState );
+ exist = (OSIterator *) copyExistingServices( matching, inState );
else
exist = 0;
return( notify );
}
+#if !defined(__LP64__)
+IONotifier * IOService::installNotification(const OSSymbol * type, OSDictionary * matching,
+ IOServiceNotificationHandler handler,
+ void * target, void * refCon,
+ SInt32 priority, OSIterator ** existing )
+{
+ IONotifier * result;
+ _IOServiceMatchingNotificationHandlerRef ref;
+ ref.handler = handler;
+ ref.ref = refCon;
+
+ result = (_IOServiceNotifier *) installNotification( type, matching,
+ &_IOServiceMatchingNotificationHandler,
+ target, &ref, priority, existing );
+ if (result)
+ matching->release();
+
+ return (result);
+}
+#endif /* !defined(__LP64__) */
+
IONotifier * IOService::installNotification(
const OSSymbol * type, OSDictionary * matching,
- IOServiceNotificationHandler handler,
+ IOServiceMatchingNotificationHandler handler,
void * target, void * ref,
SInt32 priority, OSIterator ** existing )
{
- IONotifier * notify;
+ IONotifier * notify;
LOCKWRITENOTIFY();
IONotifier * IOService::addNotification(
const OSSymbol * type, OSDictionary * matching,
IOServiceNotificationHandler handler,
- void * target, void * ref = 0,
- SInt32 priority = 0 )
+ void * target, void * refCon,
+ SInt32 priority )
+{
+ IONotifier * result;
+ _IOServiceMatchingNotificationHandlerRef ref;
+
+ ref.handler = handler;
+ ref.ref = refCon;
+
+ result = addMatchingNotification(type, matching, &_IOServiceMatchingNotificationHandler,
+ target, &ref, priority);
+
+ if (result)
+ matching->release();
+
+ return (result);
+}
+
+IONotifier * IOService::addMatchingNotification(
+ const OSSymbol * type, OSDictionary * matching,
+ IOServiceMatchingNotificationHandler handler,
+ void * target, void * ref,
+ SInt32 priority )
{
- OSIterator * existing;
+ OSIterator * existing = NULL;
_IOServiceNotifier * notify;
IOService * next;
return( notify );
}
-struct SyncNotifyVars {
- semaphore_port_t waitHere;
- IOService * result;
-};
-
bool IOService::syncNotificationHandler(
void * /* target */, void * ref,
- IOService * newService )
+ IOService * newService,
+ IONotifier * notifier )
{
- // result may get written more than once before the
- // notification is removed!
- ((SyncNotifyVars *) ref)->result = newService;
- semaphore_signal( ((SyncNotifyVars *) ref)->waitHere );
+ LOCKWRITENOTIFY();
+ if (!*((IOService **) ref))
+ {
+ newService->retain();
+ (*(IOService **) ref) = newService;
+ WAKEUPNOTIFY(ref);
+ }
+ UNLOCKNOTIFY();
return( false );
}
-IOService * IOService::waitForService( OSDictionary * matching,
- mach_timespec_t * timeout = 0 )
+IOService * IOService::waitForMatchingService( OSDictionary * matching,
+ uint64_t timeout)
{
IONotifier * notify = 0;
// priority doesn't help us much since we need a thread wakeup
SInt32 priority = 0;
- SyncNotifyVars state;
- kern_return_t err = kIOReturnBadArgument;
+ IOService * result;
- if( !matching)
+ if (!matching)
return( 0 );
- state.waitHere = 0;
- state.result = 0;
+ result = NULL;
LOCKWRITENOTIFY();
-
- do {
-
- state.result = (IOService *) getExistingServices( matching,
+ do
+ {
+ result = (IOService *) copyExistingServices( matching,
kIOServiceMatchedState, kIONotifyOnce );
- if( state.result)
- continue;
-
- err = semaphore_create( kernel_task, &state.waitHere,
- SYNC_POLICY_FIFO, 0 );
- if( KERN_SUCCESS != err)
- continue;
-
+ if (result)
+ break;
notify = IOService::setNotification( gIOMatchedNotification, matching,
&IOService::syncNotificationHandler, (void *) 0,
- (void *) &state, priority );
-
- } while( false );
-
- UNLOCKNOTIFY();
-
- if( notify) {
- if( timeout)
- err = semaphore_timedwait( state.waitHere, *timeout );
+ &result, priority );
+ if (!notify)
+ break;
+ if (UINT64_MAX != timeout)
+ {
+ AbsoluteTime deadline;
+ nanoseconds_to_absolutetime(timeout, &deadline);
+ clock_absolutetime_interval_to_deadline(deadline, &deadline);
+ SLEEPNOTIFYTO(&result, deadline);
+ }
else
- err = semaphore_wait( state.waitHere );
+ {
+ SLEEPNOTIFY(&result);
+ }
}
+ while( false );
+
+ UNLOCKNOTIFY();
- if( notify)
+ if (notify)
notify->remove(); // dequeues
+
+ return( result );
+}
+
+IOService * IOService::waitForService( OSDictionary * matching,
+ mach_timespec_t * timeout )
+{
+ IOService * result;
+ uint64_t timeoutNS;
+
+ if (timeout)
+ {
+ timeoutNS = timeout->tv_sec;
+ timeoutNS *= kSecondScale;
+ timeoutNS += timeout->tv_nsec;
+ }
else
- matching->release();
- if( state.waitHere)
- semaphore_destroy( kernel_task, state.waitHere );
+ timeoutNS = UINT64_MAX;
+
+ result = waitForMatchingService(matching, timeoutNS);
+
+ matching->release();
+ if (result)
+ result->release();
- return( state.result );
+ return (result);
}
void IOService::deliverNotification( const OSSymbol * type,
*/
OSDictionary * IOService::serviceMatching( const OSString * name,
- OSDictionary * table = 0 )
+ OSDictionary * table )
{
if( !table)
table = OSDictionary::withCapacity( 2 );
}
OSDictionary * IOService::serviceMatching( const char * name,
- OSDictionary * table = 0 )
+ OSDictionary * table )
{
const OSString * str;
}
OSDictionary * IOService::nameMatching( const OSString * name,
- OSDictionary * table = 0 )
+ OSDictionary * table )
{
if( !table)
table = OSDictionary::withCapacity( 2 );
}
OSDictionary * IOService::nameMatching( const char * name,
- OSDictionary * table = 0 )
+ OSDictionary * table )
{
const OSString * str;
}
OSDictionary * IOService::resourceMatching( const OSString * str,
- OSDictionary * table = 0 )
+ OSDictionary * table )
{
table = serviceMatching( gIOResourcesKey, table );
if( table)
}
OSDictionary * IOService::resourceMatching( const char * name,
- OSDictionary * table = 0 )
+ OSDictionary * table )
{
const OSSymbol * str;
return( table );
}
+OSDictionary * IOService::propertyMatching( const OSSymbol * key, const OSObject * value,
+ OSDictionary * table )
+{
+ OSDictionary * properties;
+
+ properties = OSDictionary::withCapacity( 2 );
+ if( !properties)
+ return( 0 );
+ properties->setObject( key, value );
+
+ if( !table)
+ table = OSDictionary::withCapacity( 2 );
+ if( table)
+ table->setObject( gIOPropertyMatchKey, properties );
+
+ properties->release();
+
+ return( table );
+}
+
+OSDictionary * IOService::registryEntryIDMatching( uint64_t entryID,
+ OSDictionary * table )
+{
+ OSNumber * num;
+
+ num = OSNumber::withNumber( entryID, 64 );
+ if( !num)
+ return( 0 );
+
+ if( !table)
+ table = OSDictionary::withCapacity( 2 );
+ if( table)
+ table->setObject( gIORegistryEntryIDKey, num );
+
+ if (num)
+ num->release();
+
+ return( table );
+}
+
+
/*
* _IOServiceNotifier
*/
}
if( doWait) {
state |= kIOServiceNotifyWaiter;
- assert_wait( this, THREAD_UNINT);
- UNLOCKNOTIFY();
- thread_block((void (*)(void)) 0);
- LOCKWRITENOTIFY();
+ SLEEPNOTIFY(this);
}
} while( doWait );
IOWorkLoop * IOResources::getWorkLoop() const
{
- // If we are the resource root then bringe over to the
- // platform to get its workloop
+ // If we are the resource root
+ // then use the platform's workloop
if (this == (IOResources *) gIOResources)
return getPlatform()->getWorkLoop();
else
return( ok );
}
+IOReturn IOResources::setProperties( OSObject * properties )
+{
+ IOReturn err;
+ const OSSymbol * key;
+ OSDictionary * dict;
+ OSCollectionIterator * iter;
+
+ err = IOUserClient::clientHasPrivilege(current_task(), kIOClientPrivilegeAdministrator);
+ if ( kIOReturnSuccess != err)
+ return( err );
+
+ dict = OSDynamicCast(OSDictionary, properties);
+ if( 0 == dict)
+ return( kIOReturnBadArgument);
+
+ iter = OSCollectionIterator::withCollection( dict);
+ if( 0 == iter)
+ return( kIOReturnBadArgument);
+
+ while( (key = OSDynamicCast(OSSymbol, iter->getNextObject()))) {
+
+ if (gIOConsoleUsersKey == key)
+ {
+ IORegistryEntry::getRegistryRoot()->setProperty(key, dict->getObject(key));
+ OSIncrementAtomic( &gIOConsoleUsersSeed );
+ publishResource( gIOConsoleUsersSeedKey, gIOConsoleUsersSeedValue );
+ continue;
+ }
+
+ publishResource( key, dict->getObject(key) );
+ }
+
+ iter->release();
+
+ return( kIOReturnSuccess );
+}
+
/*
* Helpers for matching dictionaries.
* Keys existing in matching are checked in properties.
SInt32 score;
OSNumber * newPri;
bool match = true;
+ bool matchParent = false;
UInt32 done;
assert( table );
where = this;
do {
- done = 0;
+ do {
+ done = 0;
- str = OSDynamicCast( OSString, table->getObject( gIOProviderClassKey));
- if( str) {
- done++;
- match = (0 != where->metaCast( str ));
- if( !match)
- break;
- }
+ str = OSDynamicCast( OSString, table->getObject( gIOProviderClassKey));
+ if( str) {
+ done++;
+ match = (0 != where->metaCast( str ));
+ if( !match)
+ break;
+ }
- obj = table->getObject( gIONameMatchKey );
- if( obj) {
- done++;
- match = compareNames( obj, changesOK ? &matched : 0 );
- if( !match)
- break;
- if( changesOK && matched) {
- // leave a hint as to which name matched
- table->setObject( gIONameMatchedKey, matched );
- matched->release();
+ obj = table->getObject( gIONameMatchKey );
+ if( obj) {
+ done++;
+ match = where->compareNames( obj, changesOK ? &matched : 0 );
+ if( !match)
+ break;
+ if( changesOK && matched) {
+ // leave a hint as to which name matched
+ table->setObject( gIONameMatchedKey, matched );
+ matched->release();
+ }
}
- }
- obj = table->getObject( gIOPropertyMatchKey );
- if( obj) {
-
- OSDictionary * dict;
- OSDictionary * nextDict;
- OSIterator * iter;
-
- done++;
- dict = where->dictionaryWithProperties();
- if( dict) {
- nextDict = OSDynamicCast( OSDictionary, obj);
- if( nextDict)
- iter = 0;
- else
- iter = OSCollectionIterator::withCollection(
- OSDynamicCast(OSCollection, obj));
-
- while( nextDict
- || (iter && (0 != (nextDict = OSDynamicCast(OSDictionary,
- iter->getNextObject()))))) {
- match = dict->isEqualTo( nextDict, nextDict);
- if( !match)
- break;
- nextDict = 0;
+
+ str = OSDynamicCast( OSString, table->getObject( gIOLocationMatchKey ));
+ if( str) {
+
+ const OSSymbol * sym;
+
+ done++;
+ match = false;
+ sym = where->copyLocation();
+ if( sym) {
+ match = sym->isEqualTo( str );
+ sym->release();
}
- dict->release();
- if( iter)
- iter->release();
if( !match)
break;
}
- }
- str = OSDynamicCast( OSString, table->getObject( gIOPathMatchKey ));
- if( str) {
- done++;
- entry = IORegistryEntry::fromPath( str->getCStringNoCopy() );
- match = (where == entry);
- if( entry)
- entry->release();
- if( !match)
- break;
- }
+ obj = table->getObject( gIOPropertyMatchKey );
+ if( obj) {
- num = OSDynamicCast( OSNumber, table->getObject( gIOMatchedServiceCountKey ));
- if( num) {
+ OSDictionary * dict;
+ OSDictionary * nextDict;
+ OSIterator * iter;
+
+ done++;
+ match = false;
+ dict = where->dictionaryWithProperties();
+ if( dict) {
+ nextDict = OSDynamicCast( OSDictionary, obj);
+ if( nextDict)
+ iter = 0;
+ else
+ iter = OSCollectionIterator::withCollection(
+ OSDynamicCast(OSCollection, obj));
+
+ while( nextDict
+ || (iter && (0 != (nextDict = OSDynamicCast(OSDictionary,
+ iter->getNextObject()))))) {
+ match = dict->isEqualTo( nextDict, nextDict);
+ if( match)
+ break;
+ nextDict = 0;
+ }
+ dict->release();
+ if( iter)
+ iter->release();
+ }
+ if( !match)
+ break;
+ }
- OSIterator * iter;
- IOService * service = 0;
- UInt32 serviceCount = 0;
+ str = OSDynamicCast( OSString, table->getObject( gIOPathMatchKey ));
+ if( str) {
+ done++;
+ entry = IORegistryEntry::fromPath( str->getCStringNoCopy() );
+ match = (where == entry);
+ if( entry)
+ entry->release();
+ if( !match)
+ break;
+ }
- done++;
- iter = getClientIterator();
- if( iter) {
- while( (service = (IOService *) iter->getNextObject())) {
- if( kIOServiceInactiveState & service->__state[0])
- continue;
- if( 0 == service->getProperty( gIOMatchCategoryKey ))
- continue;
- ++serviceCount;
+ num = OSDynamicCast( OSNumber, table->getObject( gIORegistryEntryIDKey ));
+ if( num) {
+ done++;
+ match = (getRegistryEntryID() == num->unsigned64BitValue());
+ }
+
+ num = OSDynamicCast( OSNumber, table->getObject( gIOMatchedServiceCountKey ));
+ if( num) {
+
+ OSIterator * iter;
+ IOService * service = 0;
+ UInt32 serviceCount = 0;
+
+ done++;
+ iter = where->getClientIterator();
+ if( iter) {
+ while( (service = (IOService *) iter->getNextObject())) {
+ if( kIOServiceInactiveState & service->__state[0])
+ continue;
+ if( 0 == service->getProperty( gIOMatchCategoryKey ))
+ continue;
+ ++serviceCount;
+ }
+ iter->release();
}
- iter->release();
+ match = (serviceCount == num->unsigned32BitValue());
+ if( !match)
+ break;
}
- match = (serviceCount == num->unsigned32BitValue());
- if( !match)
- break;
- }
- if( done == table->getCount())
- // don't call family if we've done all the entries in the table
- break;
+ if( done == table->getCount()) {
+ // don't call family if we've done all the entries in the table
+ matchParent = false;
+ break;
+ }
- // pass in score from property table
- score = IOServiceObjectOrder( table, (void *) gIOProbeScoreKey);
+ // pass in score from property table
+ score = IOServiceObjectOrder( table, (void *) gIOProbeScoreKey);
- // do family specific matching
- match = where->matchPropertyTable( table, &score );
+ // do family specific matching
+ match = where->matchPropertyTable( table, &score );
- if( !match) {
+ if( !match) {
#if IOMATCHDEBUG
- if( kIOLogMatch & getDebugFlags( table ))
- LOG("%s: family specific matching fails\n", where->getName());
+ if( kIOLogMatch & getDebugFlags( table ))
+ LOG("%s: family specific matching fails\n", where->getName());
#endif
- break;
- }
+ break;
+ }
- if( changesOK) {
- // save the score
- newPri = OSNumber::withNumber( score, 32 );
- if( newPri) {
- table->setObject( gIOProbeScoreKey, newPri );
- newPri->release();
+ if( changesOK) {
+ // save the score
+ newPri = OSNumber::withNumber( score, 32 );
+ if( newPri) {
+ table->setObject( gIOProbeScoreKey, newPri );
+ newPri->release();
+ }
}
- }
- if( !(match = where->compareProperty( table, kIOBSDNameKey )))
- break;
+ if( !(match = where->compareProperty( table, kIOBSDNameKey )))
+ break;
+ if( !(match = where->compareProperty( table, kIOBSDMajorKey )))
+ break;
+ if( !(match = where->compareProperty( table, kIOBSDMinorKey )))
+ break;
+ if( !(match = where->compareProperty( table, kIOBSDUnitKey )))
+ break;
- table = OSDynamicCast( OSDictionary,
- table->getObject( gIOLocationMatchKey ));
- if( table) {
- match = false;
- where = where->getProvider();
- if( where)
- where = where->matchLocation( where );
- }
+ matchParent = false;
+
+ obj = OSDynamicCast( OSDictionary,
+ table->getObject( gIOParentMatchKey ));
+ if( obj) {
+ match = false;
+ matchParent = true;
+ table = (OSDictionary *) obj;
+ break;
+ }
+
+ table = OSDynamicCast( OSDictionary,
+ table->getObject( gIOLocationMatchKey ));
+ if( table) {
+ match = false;
+ where = where->getProvider();
+ if( where)
+ where = where->matchLocation( where );
+ }
- } while( table && where );
+ } while( table && where );
+
+ } while( matchParent && (where = where->getProvider()) );
if( kIOLogMatch & gIOKitDebug)
if( where != this)
- LOG("match location @ %s = %d\n",
+ LOG("match parent @ %s = %d\n",
where->getName(), match );
return( match );
IOUserClient *client;
OSObject *temp;
+ if (kIOReturnSuccess == newUserClient( owningTask, securityID, type, handler ))
+ return kIOReturnSuccess;
+
// First try my own properties for a user client class name
temp = getProperty(gIOUserClientClassKey);
if (temp) {
if (!userClientClass)
return kIOReturnUnsupported;
+ // This reference is consumed by the IOServiceOpen call
temp = OSMetaClass::allocClassWithName(userClientClass);
if (!temp)
return kIOReturnNoMemory;
IOReturn IOService::newUserClient( task_t owningTask, void * securityID,
UInt32 type, IOUserClient ** handler )
{
- return( newUserClient( owningTask, securityID, type, 0, handler ));
+ return( kIOReturnUnsupported );
}
IOReturn IOService::requestProbe( IOOptionBits options )
case kIOReturnBadArgument:
return(EINVAL);
case kIOReturnUnsupported:
- return(EOPNOTSUPP);
+ return(ENOTSUP);
case kIOReturnBusy:
return(EBUSY);
case kIOReturnNoPower:
case kIOReturnExclusiveAccess:
case kIOReturnLockedRead:
case kIOReturnLockedWrite:
- case kIOReturnNotAttached:
case kIOReturnNotOpen:
case kIOReturnNotReadable:
return(EACCES);
return(EBUSY);
case kIOReturnBadMedia:
case kIOReturnNoMedia:
+ case kIOReturnNotAttached:
case kIOReturnUnformattedMedia:
- return(EIO); // (media error)
+ return(ENXIO); // (media error)
case kIOReturnDMAError:
case kIOReturnOverrun:
case kIOReturnUnderrun:
}
IOMemoryMap * IOService::mapDeviceMemoryWithIndex( unsigned int index,
- IOOptionBits options = 0 )
+ IOOptionBits options )
{
IODeviceMemory * range;
IOMemoryMap * map;
setProperty( gIODeviceMemoryKey, array);
}
+/*
+ * For machines where the transfers on an I/O bus can stall because
+ * the CPU is in an idle mode, These APIs allow a driver to specify
+ * the maximum bus stall that they can handle. 0 indicates no limit.
+ */
+void IOService::
+setCPUSnoopDelay(UInt32 __unused ns)
+{
+#if defined(__i386__) || defined(__x86_64__)
+ ml_set_maxsnoop(ns);
+#endif /* defined(__i386__) || defined(__x86_64__) */
+}
+
+UInt32 IOService::
+getCPUSnoopDelay()
+{
+#if defined(__i386__) || defined(__x86_64__)
+ return ml_get_maxsnoop();
+#else
+ return 0;
+#endif /* defined(__i386__) || defined(__x86_64__) */
+}
+
+#if defined(__i386__) || defined(__x86_64__)
+static void
+requireMaxCpuDelay(IOService * service, UInt32 ns, UInt32 delayType)
+{
+ static const UInt kNoReplace = -1U; // Must be an illegal index
+ UInt replace = kNoReplace;
+ bool setCpuDelay = false;
+
+ IORecursiveLockLock(sCpuDelayLock);
+
+ UInt count = sCpuDelayData->getLength() / sizeof(CpuDelayEntry);
+ CpuDelayEntry *entries = (CpuDelayEntry *) sCpuDelayData->getBytesNoCopy();
+ IOService * holder = NULL;
+
+ if (ns) {
+ const CpuDelayEntry ne = {service, ns, delayType};
+ holder = service;
+ // Set maximum delay.
+ for (UInt i = 0; i < count; i++) {
+ IOService *thisService = entries[i].fService;
+ bool sameType = (delayType == entries[i].fDelayType);
+ if ((service == thisService) && sameType)
+ replace = i;
+ else if (!thisService) {
+ if (kNoReplace == replace)
+ replace = i;
+ }
+ else if (sameType) {
+ const UInt32 thisMax = entries[i].fMaxDelay;
+ if (thisMax < ns)
+ {
+ ns = thisMax;
+ holder = thisService;
+ }
+ }
+ }
+
+ setCpuDelay = true;
+ if (kNoReplace == replace)
+ sCpuDelayData->appendBytes(&ne, sizeof(ne));
+ else
+ entries[replace] = ne;
+ }
+ else {
+ ns = -1U; // Set to max unsigned, i.e. no restriction
+
+ for (UInt i = 0; i < count; i++) {
+ // Clear a maximum delay.
+ IOService *thisService = entries[i].fService;
+ if (thisService && (delayType == entries[i].fDelayType)) {
+ UInt32 thisMax = entries[i].fMaxDelay;
+ if (service == thisService)
+ replace = i;
+ else if (thisMax < ns) {
+ ns = thisMax;
+ holder = thisService;
+ }
+ }
+ }
+
+ // Check if entry found
+ if (kNoReplace != replace) {
+ entries[replace].fService = 0; // Null the entry
+ setCpuDelay = true;
+ }
+ }
+
+ if (setCpuDelay)
+ {
+ // Must be safe to call from locked context
+ if (delayType == kCpuDelayBusStall)
+ {
+ ml_set_maxbusdelay(ns);
+ }
+ else if (delayType == kCpuDelayInterrupt)
+ {
+ ml_set_maxintdelay(ns);
+ }
+
+ OSArray * handlers = sCpuLatencyHandlers[delayType];
+ IOService * target;
+ if (handlers) for (unsigned int idx = 0;
+ (target = (IOService *) handlers->getObject(idx));
+ idx++)
+ {
+ target->callPlatformFunction(sCPULatencyFunctionName[delayType], false,
+ (void *) (uintptr_t) ns, holder,
+ NULL, NULL);
+ }
+ }
+
+ IORecursiveLockUnlock(sCpuDelayLock);
+}
+
+static IOReturn
+setLatencyHandler(UInt32 delayType, IOService * target, bool enable)
+{
+ IOReturn result = kIOReturnNotFound;
+ OSArray * array;
+ unsigned int idx;
+
+ IORecursiveLockLock(sCpuDelayLock);
+
+ do
+ {
+ if (enable && !sCpuLatencyHandlers[delayType])
+ sCpuLatencyHandlers[delayType] = OSArray::withCapacity(4);
+ array = sCpuLatencyHandlers[delayType];
+ if (!array)
+ break;
+ idx = array->getNextIndexOfObject(target, 0);
+ if (!enable)
+ {
+ if (-1U != idx)
+ {
+ array->removeObject(idx);
+ result = kIOReturnSuccess;
+ }
+ }
+ else
+ {
+ if (-1U != idx) {
+ result = kIOReturnExclusiveAccess;
+ break;
+ }
+ array->setObject(target);
+
+ UInt count = sCpuDelayData->getLength() / sizeof(CpuDelayEntry);
+ CpuDelayEntry *entries = (CpuDelayEntry *) sCpuDelayData->getBytesNoCopy();
+ UInt32 ns = -1U; // Set to max unsigned, i.e. no restriction
+ IOService * holder = NULL;
+
+ for (UInt i = 0; i < count; i++) {
+ if (entries[i].fService
+ && (delayType == entries[i].fDelayType)
+ && (entries[i].fMaxDelay < ns)) {
+ ns = entries[i].fMaxDelay;
+ holder = entries[i].fService;
+ }
+ }
+ target->callPlatformFunction(sCPULatencyFunctionName[delayType], false,
+ (void *) (uintptr_t) ns, holder,
+ NULL, NULL);
+ result = kIOReturnSuccess;
+ }
+ }
+ while (false);
+
+ IORecursiveLockUnlock(sCpuDelayLock);
+
+ return (result);
+}
+
+#endif /* defined(__i386__) || defined(__x86_64__) */
+
+void IOService::
+requireMaxBusStall(UInt32 __unused ns)
+{
+#if defined(__i386__) || defined(__x86_64__)
+ requireMaxCpuDelay(this, ns, kCpuDelayBusStall);
+#endif
+}
+
+void IOService::
+requireMaxInterruptDelay(uint32_t __unused ns)
+{
+#if defined(__i386__) || defined(__x86_64__)
+ requireMaxCpuDelay(this, ns, kCpuDelayInterrupt);
+#endif
+}
+
/*
* Device interrupts
*/
IOReturn IOService::resolveInterrupt(IOService *nub, int source)
{
IOInterruptController *interruptController;
- OSDictionary *propTable;
OSArray *array;
OSData *data;
OSSymbol *interruptControllerName;
long numSources;
IOInterruptSource *interruptSources;
- // Get the property table from the nub.
- propTable = nub->getPropertyTable();
- if (propTable == 0) return kIOReturnNoResources;
-
- // Get the parents list from the property table.
- array = OSDynamicCast(OSArray,
- propTable->getObject(gIOInterruptControllersKey));
+ // Get the parents list from the nub.
+ array = OSDynamicCast(OSArray, nub->getProperty(gIOInterruptControllersKey));
if (array == 0) return kIOReturnNoResources;
// Allocate space for the IOInterruptSources if needed... then return early.
interruptController = getPlatform()->lookUpInterruptController(interruptControllerName);
if (interruptController == 0) return kIOReturnNoResources;
- // Get the interrupt numbers from the property table.
- array = OSDynamicCast(OSArray,
- propTable->getObject(gIOInterruptSpecifiersKey));
+ // Get the interrupt numbers from the nub.
+ array = OSDynamicCast(OSArray, nub->getProperty(gIOInterruptSpecifiersKey));
if (array == 0) return kIOReturnNoResources;
data = OSDynamicCast(OSData, array->getObject(source));
if (data == 0) return kIOReturnNoResources;
return interruptController->causeInterrupt(this, source);
}
+#if __LP64__
OSMetaClassDefineReservedUnused(IOService, 0);
OSMetaClassDefineReservedUnused(IOService, 1);
OSMetaClassDefineReservedUnused(IOService, 2);
OSMetaClassDefineReservedUnused(IOService, 3);
OSMetaClassDefineReservedUnused(IOService, 4);
OSMetaClassDefineReservedUnused(IOService, 5);
+#else
+OSMetaClassDefineReservedUsed(IOService, 0);
+OSMetaClassDefineReservedUsed(IOService, 1);
+OSMetaClassDefineReservedUsed(IOService, 2);
+OSMetaClassDefineReservedUsed(IOService, 3);
+OSMetaClassDefineReservedUsed(IOService, 4);
+OSMetaClassDefineReservedUsed(IOService, 5);
+#endif
OSMetaClassDefineReservedUnused(IOService, 6);
OSMetaClassDefineReservedUnused(IOService, 7);
OSMetaClassDefineReservedUnused(IOService, 8);
OSMetaClassDefineReservedUnused(IOService, 45);
OSMetaClassDefineReservedUnused(IOService, 46);
OSMetaClassDefineReservedUnused(IOService, 47);
+
+#ifdef __ppc__
OSMetaClassDefineReservedUnused(IOService, 48);
OSMetaClassDefineReservedUnused(IOService, 49);
OSMetaClassDefineReservedUnused(IOService, 50);
OSMetaClassDefineReservedUnused(IOService, 61);
OSMetaClassDefineReservedUnused(IOService, 62);
OSMetaClassDefineReservedUnused(IOService, 63);
+#endif