Go to the source code of this file.
Classes | |
struct | _KTHREAD_SWITCH_COUNTERS |
struct | _KAPC_STATE |
struct | _DISPATCHER_HEADER |
struct | _KWAIT_BLOCK |
struct | _KSERVICE_TABLE_DESCRIPTOR |
struct | _KDEVICE_QUEUE |
struct | _KDEVICE_QUEUE_ENTRY |
struct | _KEVENT |
struct | _KEVENT_PAIR |
struct | _KINTERRUPT |
struct | _KMUTANT |
struct | _KQUEUE |
struct | _KSEMAPHORE |
struct | _KTIMER |
struct | _KTHREAD |
struct | _KPROCESS |
struct | _KPROFILE |
struct | _ECHANNEL |
struct | _KBUGCHECK_CALLBACK_RECORD |
Defines | |
#define | CLOCK_QUANTUM_DECREMENT 3 |
#define | WAIT_QUANTUM_DECREMENT 1 |
#define | READY_SKIP_QUANTUM 2 |
#define | THREAD_QUANTUM (READY_SKIP_QUANTUM * CLOCK_QUANTUM_DECREMENT) |
#define | ROUND_TRIP_DECREMENT_COUNT 16 |
#define | BASE_PRIORITY_THRESHOLD NORMAL_BASE_PRIORITY |
#define | THREAD_WAIT_OBJECTS 3 |
#define | EVENT_WAIT_BLOCK 2 |
#define | SEMAPHORE_WAIT_BLOCK 2 |
#define | TIMER_WAIT_BLOCK 3 |
#define | TIMER_TABLE_SIZE 128 |
#define | KeGetCurrentApcEnvironment() KeGetCurrentThread()->ApcStateIndex |
#define | DISPATCHER_OBJECT_TYPE_MASK 0x7 |
#define | NUMBER_SERVICE_TABLES 4 |
#define | SERVICE_NUMBER_MASK ((1 << 12) - 1) |
#define | SERVICE_TABLE_SHIFT (12 - 4) |
#define | SERVICE_TABLE_MASK (((1 << 2) - 1) << 4) |
#define | SERVICE_TABLE_TEST (WIN32K_SERVICE_INDEX << 4) |
#define | LISTEN_CHANNEL 0x1 |
#define | MESSAGE_CHANNEL 0x2 |
#define | KeInitializeEvent(_Event, _Type, _State) |
#define | KeClearEvent(Event) (Event)->Header.SignalState = 0 |
#define | KeSetHighEventPair(EventPair, Increment, Wait) |
#define | KeSetLowEventPair(EventPair, Increment, Wait) |
#define | KeReadStateMutex(Mutex) KeReadStateMutant(Mutex) |
#define | KeIsAttachedProcess() (KeGetCurrentThread()->ApcStateIndex == AttachedApcEnvironment) |
#define | KeTerminateProcess(Process) (Process)->StackCount += 1; |
#define | KiLeaveCriticalRegion() |
#define | KeEnterCriticalRegion() KeGetCurrentThread()->KernelApcDisable -= 1; |
#define | KeLeaveCriticalRegion() KiLeaveCriticalRegion() |
#define | KeSetHighWaitLowEventPair(EventPair, WaitMode) |
#define | KeSetLowWaitHighEventPair(EventPair, WaitMode) |
#define | KeWaitForHighEventPair(EventPair, WaitMode, Alertable, TimeOut) |
#define | KeWaitForLowEventPair(EventPair, WaitMode, Alertable, TimeOut) |
#define | KeWaitForMutexObject KeWaitForSingleObject |
#define | _DECL_HAL_KE_IMPORT |
#define | KiLockDispatcherDatabase(OldIrql) *(OldIrql) = KeAcquireSpinLockRaiseToSynch(&KiDispatcherLock) |
#define | KeAcquireSpinLock(SpinLock, OldIrql) *(OldIrql) = KeAcquireSpinLockRaiseToDpc(SpinLock) |
#define | KeInitializeCallbackRecord(CallbackRecord) (CallbackRecord)->State = BufferEmpty |
#define | KeFindFirstSetRightMember(Set) |
#define | DMA_READ_DCACHE_INVALIDATE 0x1 |
#define | DMA_READ_ICACHE_INVALIDATE 0x2 |
#define | DMA_WRITE_DCACHE_SNOOP 0x4 |
#define | SYSTEM_SERVICE_INDEX 0 |
#define | WIN32K_SERVICE_INDEX 1 |
#define | IIS_SERVICE_INDEX 2 |
Typedefs | |
typedef _KTHREAD_SWITCH_COUNTERS | KTHREAD_SWITCH_COUNTERS |
typedef _KTHREAD_SWITCH_COUNTERS * | PKTHREAD_SWITCH_COUNTERS |
typedef enum _KOBJECTS | KOBJECTS |
typedef enum _KAPC_ENVIRONMENT | KAPC_ENVIRONMENT |
typedef enum _KINTERRUPT_MODE | KINTERRUPT_MODE |
typedef enum _KPROCESS_STATE | KPROCESS_STATE |
typedef enum _KTHREAD_STATE | KTHREAD_STATE |
typedef enum _KWAIT_REASON | KWAIT_REASON |
typedef _KAPC_STATE | KAPC_STATE |
typedef _KAPC_STATE * | PKAPC_STATE |
typedef _KAPC_STATE | PRKAPC_STATE |
typedef _DISPATCHER_HEADER | DISPATCHER_HEADER |
typedef ULONG | KPAGE_FRAME |
typedef _KWAIT_BLOCK | KWAIT_BLOCK |
typedef _KWAIT_BLOCK * | PKWAIT_BLOCK |
typedef _KWAIT_BLOCK | PRKWAIT_BLOCK |
typedef _KSERVICE_TABLE_DESCRIPTOR | KSERVICE_TABLE_DESCRIPTOR |
typedef _KSERVICE_TABLE_DESCRIPTOR * | PKSERVICE_TABLE_DESCRIPTOR |
typedef BOOLEAN(* | PKDEBUG_ROUTINE )(IN PKTRAP_FRAME TrapFrame, IN PKEXCEPTION_FRAME ExceptionFrame, IN PEXCEPTION_RECORD ExceptionRecord, IN PCONTEXT ContextRecord, IN KPROCESSOR_MODE PreviousMode, IN BOOLEAN SecondChance) |
typedef BOOLEAN(* | PKDEBUG_SWITCH_ROUTINE )(IN PEXCEPTION_RECORD ExceptionRecord, IN PCONTEXT ContextRecord, IN BOOLEAN SecondChance) |
typedef VOID(* | PKSTART_ROUTINE )(IN PVOID StartContext) |
typedef VOID(* | PKSYSTEM_ROUTINE )(IN PKSTART_ROUTINE StartRoutine OPTIONAL, IN PVOID StartContext OPTIONAL) |
typedef _KDEVICE_QUEUE | KDEVICE_QUEUE |
typedef _KDEVICE_QUEUE * | PKDEVICE_QUEUE |
typedef _KDEVICE_QUEUE | PRKDEVICE_QUEUE |
typedef _KDEVICE_QUEUE_ENTRY | KDEVICE_QUEUE_ENTRY |
typedef _KDEVICE_QUEUE_ENTRY * | PKDEVICE_QUEUE_ENTRY |
typedef _KDEVICE_QUEUE_ENTRY | PRKDEVICE_QUEUE_ENTRY |
typedef _KEVENT | KEVENT |
typedef _KEVENT * | PKEVENT |
typedef _KEVENT | PRKEVENT |
typedef _KEVENT_PAIR | KEVENT_PAIR |
typedef _KEVENT_PAIR * | PKEVENT_PAIR |
typedef _KEVENT_PAIR | PRKEVENT_PAIR |
typedef BOOLEAN(* | PKSERVICE_ROUTINE )(IN struct _KINTERRUPT *Interrupt, IN PVOID ServiceContext) |
typedef _KINTERRUPT | KINTERRUPT |
typedef _KINTERRUPT * | PKINTERRUPT |
typedef _KINTERRUPT *RESTRICTED_POINTER | PRKINTERRUPT |
typedef _KMUTANT | KMUTANT |
typedef _KMUTANT * | PKMUTANT |
typedef _KMUTANT | PRKMUTANT |
typedef _KMUTANT | KMUTEX |
typedef _KMUTANT * | PKMUTEX |
typedef _KMUTANT | PRKMUTEX |
typedef _KQUEUE | KQUEUE |
typedef _KQUEUE * | PKQUEUE |
typedef _KQUEUE | PRKQUEUE |
typedef _KSEMAPHORE | KSEMAPHORE |
typedef _KSEMAPHORE * | PKSEMAPHORE |
typedef _KSEMAPHORE | PRKSEMAPHORE |
typedef _KTIMER | KTIMER |
typedef _KTIMER * | PKTIMER |
typedef _KTIMER | PRKTIMER |
typedef _KTHREAD | KTHREAD |
typedef _KTHREAD * | PKTHREAD |
typedef _KTHREAD | PRKTHREAD |
typedef _KPROCESS | KPROCESS |
typedef _KPROCESS * | PKPROCESS |
typedef _KPROCESS | PRKPROCESS |
typedef _KPROFILE | KPROFILE |
typedef _KPROFILE * | PKPROFILE |
typedef _KPROFILE | PRKPROFILE |
typedef enum _ECHANNEL_STATE | ECHANNEL_STATE |
typedef _ECHANNEL | ECHANNEL |
typedef _ECHANNEL * | PECHANNEL |
typedef _ECHANNEL | PRECHANNEL |
typedef enum _KBUGCHECK_BUFFER_DUMP_STATE | KBUGCHECK_BUFFER_DUMP_STATE |
typedef VOID(* | PKBUGCHECK_CALLBACK_ROUTINE )(IN PVOID Buffer, IN ULONG Length) |
typedef _KBUGCHECK_CALLBACK_RECORD | KBUGCHECK_CALLBACK_RECORD |
typedef _KBUGCHECK_CALLBACK_RECORD * | PKBUGCHECK_CALLBACK_RECORD |
typedef PCHAR(* | PKE_BUGCHECK_UNICODE_TO_ANSI )(IN PUNICODE_STRING UnicodeString, OUT PCHAR AnsiBuffer, IN ULONG MaxAnsiLength) |
typedef VOID(* | PGDI_BATCHFLUSH_ROUTINE )(VOID) |
typedef enum _FIRMWARE_REENTRY | FIRMWARE_REENTRY |
typedef enum _FIRMWARE_REENTRY * | PFIRMWARE_REENTRY |
typedef VOID(FASTCALL * | PSWAP_CONTEXT_NOTIFY_ROUTINE )(IN HANDLE OldThreadId, IN HANDLE NewThreadId) |
typedef LOGICAL(FASTCALL * | PTHREAD_SELECT_NOTIFY_ROUTINE )(IN HANDLE ThreadId) |
typedef VOID(FASTCALL * | PTIME_UPDATE_NOTIFY_ROUTINE )(IN HANDLE ThreadId, IN KPROCESSOR_MODE Mode) |
typedef enum _MEMORY_CACHING_TYPE_ORIG | MEMORY_CACHING_TYPE_ORIG |
typedef enum _MEMORY_CACHING_TYPE | MEMORY_CACHING_TYPE |
Enumerations | |
enum | _KOBJECTS { EventNotificationObject = 0, EventSynchronizationObject = 1, MutantObject = 2, ProcessObject = 3, QueueObject = 4, SemaphoreObject = 5, ThreadObject = 6, Spare1Object = 7, TimerNotificationObject = 8, TimerSynchronizationObject = 9, Spare2Object = 10, Spare3Object = 11, Spare4Object = 12, Spare5Object = 13, Spare6Object = 14, Spare7Object = 15, Spare8Object = 16, Spare9Object = 17, ApcObject, DpcObject, DeviceQueueObject, EventPairObject, InterruptObject, ProfileObject } |
enum | _KAPC_ENVIRONMENT { OriginalApcEnvironment, AttachedApcEnvironment, CurrentApcEnvironment } |
enum | _KINTERRUPT_MODE { LevelSensitive, Latched } |
enum | _KPROCESS_STATE { ProcessInMemory, ProcessOutOfMemory, ProcessInTransition, ProcessInSwap, ProcessOutSwap } |
enum | _KTHREAD_STATE { Initialized, Ready, Running, Standby, Terminated, Waiting, Transition } |
enum | _KWAIT_REASON { Executive, FreePage, PageIn, PoolAllocation, DelayExecution, Suspended, UserRequest, WrExecutive, WrFreePage, WrPageIn, WrPoolAllocation, WrDelayExecution, WrSuspended, WrUserRequest, WrEventPair, WrQueue, WrLpcReceive, WrLpcReply, WrVirtualMemory, WrPageOut, WrRendezvous, Spare2, Spare3, Spare4, Spare5, Spare6, WrKernel, MaximumWaitReason } |
enum | KCONTINUE_STATUS { ContinueError = FALSE, ContinueSuccess = TRUE, ContinueProcessorReselected, ContinueNextProcessor } |
enum | _ECHANNEL_STATE { ClientIdle, ClientSendWaitReply, ClientShutdown, ServerIdle, ServerReceiveMessage, ServerShutdown } |
enum | _KBUGCHECK_BUFFER_DUMP_STATE { BufferEmpty, BufferInserted, BufferStarted, BufferFinished, BufferIncomplete } |
enum | _FIRMWARE_REENTRY { HalHaltRoutine, HalPowerDownRoutine, HalRestartRoutine, HalRebootRoutine, HalInteractiveModeRoutine, HalMaximumRoutine } |
enum | _MEMORY_CACHING_TYPE_ORIG { MmFrameBufferCached = 2 } |
enum | _MEMORY_CACHING_TYPE { MmNonCached = FALSE, MmCached = TRUE, MmWriteCombined = MmFrameBufferCached, MmHardwareCoherentCached, MmNonCachedUnordered, MmUSWCCached, MmMaximumCacheType } |
Functions | |
NTKERNELAPI VOID | KeInitializeApc (IN PRKAPC Apc, IN PRKTHREAD Thread, IN KAPC_ENVIRONMENT Environment, IN PKKERNEL_ROUTINE KernelRoutine, IN PKRUNDOWN_ROUTINE RundownRoutine OPTIONAL, IN PKNORMAL_ROUTINE NormalRoutine OPTIONAL, IN KPROCESSOR_MODE ProcessorMode OPTIONAL, IN PVOID NormalContext OPTIONAL) |
PLIST_ENTRY | KeFlushQueueApc (IN PKTHREAD Thread, IN KPROCESSOR_MODE ProcessorMode) |
NTKERNELAPI BOOLEAN | KeInsertQueueApc (IN PRKAPC Apc, IN PVOID SystemArgument1, IN PVOID SystemArgument2, IN KPRIORITY Increment) |
BOOLEAN | KeRemoveQueueApc (IN PKAPC Apc) |
NTKERNELAPI VOID | KeInitializeDpc (IN PRKDPC Dpc, IN PKDEFERRED_ROUTINE DeferredRoutine, IN PVOID DeferredContext) |
NTKERNELAPI BOOLEAN | KeInsertQueueDpc (IN PRKDPC Dpc, IN PVOID SystemArgument1, IN PVOID SystemArgument2) |
NTKERNELAPI BOOLEAN | KeRemoveQueueDpc (IN PRKDPC Dpc) |
NTKERNELAPI VOID | KeSetImportanceDpc (IN PRKDPC Dpc, IN KDPC_IMPORTANCE Importance) |
NTKERNELAPI VOID | KeSetTargetProcessorDpc (IN PRKDPC Dpc, IN CCHAR Number) |
NTKERNELAPI VOID | KeInitializeDeviceQueue (IN PKDEVICE_QUEUE DeviceQueue) |
NTKERNELAPI BOOLEAN | KeInsertDeviceQueue (IN PKDEVICE_QUEUE DeviceQueue, IN PKDEVICE_QUEUE_ENTRY DeviceQueueEntry) |
NTKERNELAPI BOOLEAN | KeInsertByKeyDeviceQueue (IN PKDEVICE_QUEUE DeviceQueue, IN PKDEVICE_QUEUE_ENTRY DeviceQueueEntry, IN ULONG SortKey) |
NTKERNELAPI PKDEVICE_QUEUE_ENTRY | KeRemoveDeviceQueue (IN PKDEVICE_QUEUE DeviceQueue) |
NTKERNELAPI PKDEVICE_QUEUE_ENTRY | KeRemoveByKeyDeviceQueue (IN PKDEVICE_QUEUE DeviceQueue, IN ULONG SortKey) |
NTKERNELAPI BOOLEAN | KeRemoveEntryDeviceQueue (IN PKDEVICE_QUEUE DeviceQueue, IN PKDEVICE_QUEUE_ENTRY DeviceQueueEntry) |
NTKERNELAPI VOID | KeInitializeInterrupt (IN PKINTERRUPT Interrupt, IN PKSERVICE_ROUTINE ServiceRoutine, IN PVOID ServiceContext, IN PKSPIN_LOCK SpinLock OPTIONAL, IN ULONG Vector, IN KIRQL Irql, IN KIRQL SynchronizeIrql, IN KINTERRUPT_MODE InterruptMode, IN BOOLEAN ShareVector, IN CCHAR ProcessorNumber, IN BOOLEAN FloatingSave) |
NTKERNELAPI BOOLEAN | KeConnectInterrupt (IN PKINTERRUPT Interrupt) |
NTKERNELAPI BOOLEAN | KeDisconnectInterrupt (IN PKINTERRUPT Interrupt) |
NTKERNELAPI BOOLEAN | KeSynchronizeExecution (IN PKINTERRUPT Interrupt, IN PKSYNCHRONIZE_ROUTINE SynchronizeRoutine, IN PVOID SynchronizeContext) |
VOID | KeInitializeProfile (IN PKPROFILE Profile, IN PKPROCESS Process OPTIONAL, IN PVOID RangeBase, IN SIZE_T RangeSize, IN ULONG BucketSize, IN ULONG Segment, IN KPROFILE_SOURCE ProfileSource, IN KAFFINITY Affinity) |
BOOLEAN | KeStartProfile (IN PKPROFILE Profile, IN PULONG Buffer) |
BOOLEAN | KeStopProfile (IN PKPROFILE Profile) |
VOID | KeSetIntervalProfile (IN ULONG Interval, IN KPROFILE_SOURCE Source) |
ULONG | KeQueryIntervalProfile (IN KPROFILE_SOURCE Source) |
NTKERNELAPI LONG | KePulseEvent (IN PRKEVENT Event, IN KPRIORITY Increment, IN BOOLEAN Wait) |
NTKERNELAPI LONG | KeReadStateEvent (IN PRKEVENT Event) |
NTKERNELAPI LONG | KeResetEvent (IN PRKEVENT Event) |
NTKERNELAPI LONG | KeSetEvent (IN PRKEVENT Event, IN KPRIORITY Increment, IN BOOLEAN Wait) |
VOID | KeSetEventBoostPriority (IN PRKEVENT Event, IN PRKTHREAD *Thread OPTIONAL) |
VOID | KeInitializeEventPair (IN PKEVENT_PAIR EventPair) |
NTKERNELAPI VOID | KeInitializeMutant (IN PRKMUTANT Mutant, IN BOOLEAN InitialOwner) |
LONG | KeReadStateMutant (IN PRKMUTANT) |
NTKERNELAPI LONG | KeReleaseMutant (IN PRKMUTANT Mutant, IN KPRIORITY Increment, IN BOOLEAN Abandoned, IN BOOLEAN Wait) |
NTKERNELAPI VOID | KeInitializeMutex (IN PRKMUTEX Mutex, IN ULONG Level) |
NTKERNELAPI LONG | KeReleaseMutex (IN PRKMUTEX Mutex, IN BOOLEAN Wait) |
NTKERNELAPI VOID | KeInitializeQueue (IN PRKQUEUE Queue, IN ULONG Count OPTIONAL) |
NTKERNELAPI LONG | KeReadStateQueue (IN PRKQUEUE Queue) |
NTKERNELAPI LONG | KeInsertQueue (IN PRKQUEUE Queue, IN PLIST_ENTRY Entry) |
NTKERNELAPI LONG | KeInsertHeadQueue (IN PRKQUEUE Queue, IN PLIST_ENTRY Entry) |
NTKERNELAPI PLIST_ENTRY | KeRemoveQueue (IN PRKQUEUE Queue, IN KPROCESSOR_MODE WaitMode, IN PLARGE_INTEGER Timeout OPTIONAL) |
PLIST_ENTRY | KeRundownQueue (IN PRKQUEUE Queue) |
NTKERNELAPI VOID | KeInitializeSemaphore (IN PRKSEMAPHORE Semaphore, IN LONG Count, IN LONG Limit) |
NTKERNELAPI LONG | KeReadStateSemaphore (IN PRKSEMAPHORE Semaphore) |
NTKERNELAPI LONG | KeReleaseSemaphore (IN PRKSEMAPHORE Semaphore, IN KPRIORITY Increment, IN LONG Adjustment, IN BOOLEAN Wait) |
VOID | KeInitializeProcess (IN PRKPROCESS Process, IN KPRIORITY Priority, IN KAFFINITY Affinity, IN ULONG_PTR DirectoryTableBase[2], IN BOOLEAN Enable) |
LOGICAL | KeForceAttachProcess (IN PKPROCESS Process) |
NTKERNELAPI VOID | KeAttachProcess (IN PRKPROCESS Process) |
NTKERNELAPI VOID | KeDetachProcess (VOID) |
NTKERNELAPI VOID | KeStackAttachProcess (IN PRKPROCESS PROCESS, OUT PRKAPC_STATE ApcState) |
NTKERNELAPI VOID | KeUnstackDetachProcess (IN PRKAPC_STATE ApcState) |
LONG | KeReadStateProcess (IN PRKPROCESS Process) |
BOOLEAN | KeSetAutoAlignmentProcess (IN PRKPROCESS Process, IN BOOLEAN Enable) |
LONG | KeSetProcess (IN PRKPROCESS Process, IN KPRIORITY Increment, IN BOOLEAN Wait) |
KPRIORITY | KeSetPriorityProcess (IN PKPROCESS Process, IN KPRIORITY BasePriority) |
LOGICAL | KeSetDisableQuantumProcess (IN PKPROCESS Process, IN LOGICAL Disable) |
VOID | KeInitializeThread (IN PKTHREAD Thread, IN PVOID KernelStack, IN PKSYSTEM_ROUTINE SystemRoutine, IN PKSTART_ROUTINE StartRoutine OPTIONAL, IN PVOID StartContext OPTIONAL, IN PCONTEXT ContextFrame OPTIONAL, IN PVOID Teb OPTIONAL, IN PKPROCESS Process) |
BOOLEAN | KeAlertThread (IN PKTHREAD Thread, IN KPROCESSOR_MODE ProcessorMode) |
ULONG | KeAlertResumeThread (IN PKTHREAD Thread) |
NTKERNELAPI VOID | KeBoostCurrentThread (VOID) |
VOID | KeBoostPriorityThread (IN PKTHREAD Thread, IN KPRIORITY Increment) |
KAFFINITY | KeConfineThread (VOID) |
NTKERNELAPI NTSTATUS | KeDelayExecutionThread (IN KPROCESSOR_MODE WaitMode, IN BOOLEAN Alertable, IN PLARGE_INTEGER Interval) |
BOOLEAN | KeDisableApcQueuingThread (IN PKTHREAD Thread) |
BOOLEAN | KeEnableApcQueuingThread (IN PKTHREAD) |
LOGICAL | KeSetDisableBoostThread (IN PKTHREAD Thread, IN LOGICAL Disable) |
ULONG | KeForceResumeThread (IN PKTHREAD Thread) |
VOID | KeFreezeAllThreads (VOID) |
BOOLEAN | KeQueryAutoAlignmentThread (IN PKTHREAD Thread) |
LONG | KeQueryBasePriorityThread (IN PKTHREAD Thread) |
NTKERNELAPI KPRIORITY | KeQueryPriorityThread (IN PKTHREAD Thread) |
BOOLEAN | KeReadStateThread (IN PKTHREAD Thread) |
VOID | KeReadyThread (IN PKTHREAD Thread) |
ULONG | KeResumeThread (IN PKTHREAD Thread) |
VOID | KeRevertToUserAffinityThread (VOID) |
VOID | KeRundownThread (VOID) |
KAFFINITY | KeSetAffinityThread (IN PKTHREAD Thread, IN KAFFINITY Affinity) |
VOID | KeSetSystemAffinityThread (IN KAFFINITY Affinity) |
BOOLEAN | KeSetAutoAlignmentThread (IN PKTHREAD Thread, IN BOOLEAN Enable) |
NTKERNELAPI LONG | KeSetBasePriorityThread (IN PKTHREAD Thread, IN LONG Increment) |
NTKERNELAPI CCHAR | KeSetIdealProcessorThread (IN PKTHREAD Thread, IN CCHAR Processor) |
NTKERNELAPI BOOLEAN | KeSetKernelStackSwapEnable (IN BOOLEAN Enable) |
NTKERNELAPI KPRIORITY | KeSetPriorityThread (IN PKTHREAD Thread, IN KPRIORITY Priority) |
ULONG | KeSuspendThread (IN PKTHREAD) |
NTKERNELAPI VOID | KeTerminateThread (IN KPRIORITY Increment) |
BOOLEAN | KeTestAlertThread (IN KPROCESSOR_MODE) |
VOID | KeThawAllThreads (VOID) |
NTKERNELAPI VOID | KeInitializeTimer (IN PKTIMER Timer) |
NTKERNELAPI VOID | KeInitializeTimerEx (IN PKTIMER Timer, IN TIMER_TYPE Type) |
NTKERNELAPI BOOLEAN | KeCancelTimer (IN PKTIMER) |
NTKERNELAPI BOOLEAN | KeReadStateTimer (PKTIMER Timer) |
NTKERNELAPI BOOLEAN | KeSetTimer (IN PKTIMER Timer, IN LARGE_INTEGER DueTime, IN PKDPC Dpc OPTIONAL) |
NTKERNELAPI BOOLEAN | KeSetTimerEx (IN PKTIMER Timer, IN LARGE_INTEGER DueTime, IN LONG Period OPTIONAL, IN PKDPC Dpc OPTIONAL) |
PVOID | KeCheckForTimer (IN PVOID p, IN ULONG Size) |
VOID | KeClearTimer (IN PKTIMER Timer) |
ULONGLONG | KeQueryTimerDueTime (IN PKTIMER Timer) |
NTSTATUS | KiSetServerWaitClientEvent (IN PKEVENT SeverEvent, IN PKEVENT ClientEvent, IN ULONG WaitMode) |
NTKERNELAPI NTSTATUS | KeWaitForMultipleObjects (IN ULONG Count, IN PVOID Object[], IN WAIT_TYPE WaitType, IN KWAIT_REASON WaitReason, IN KPROCESSOR_MODE WaitMode, IN BOOLEAN Alertable, IN PLARGE_INTEGER Timeout OPTIONAL, IN PKWAIT_BLOCK WaitBlockArray OPTIONAL) |
NTKERNELAPI NTSTATUS | KeWaitForSingleObject (IN PVOID Object, IN KWAIT_REASON WaitReason, IN KPROCESSOR_MODE WaitMode, IN BOOLEAN Alertable, IN PLARGE_INTEGER Timeout OPTIONAL) |
VOID FASTCALL | KiSetPriorityThread (IN PRKTHREAD Thread, IN KPRIORITY Priority) |
NTKERNELAPI VOID NTAPI | KeInitializeSpinLock (IN PKSPIN_LOCK SpinLock) |
NTKERNELAPI KIRQL FASTCALL | KeAcquireSpinLockRaiseToSynch (IN PKSPIN_LOCK SpinLock) |
NTKERNELAPI VOID | KeAcquireSpinLockAtDpcLevel (IN PKSPIN_LOCK SpinLock) |
NTKERNELAPI VOID | KeReleaseSpinLockFromDpcLevel (IN PKSPIN_LOCK SpinLock) |
NTKERNELAPI KIRQL | KeAcquireSpinLockRaiseToDpc (IN PKSPIN_LOCK SpinLock) |
NTKERNELAPI VOID | KeReleaseSpinLock (IN PKSPIN_LOCK SpinLock, IN KIRQL NewIrql) |
BOOLEAN | KeTryToAcquireSpinLock (IN PKSPIN_LOCK SpinLock, OUT PKIRQL OldIrql) |
BOOLEAN | KeInitSystem (VOID) |
BOOLEAN | KeGetBugMessageText (IN ULONG MessageId, IN PANSI_STRING ReturnedString OPTIONAL) |
NTKERNELAPI DECLSPEC_NORETURN VOID NTAPI | KeBugCheck (IN ULONG BugCheckCode) |
NTKERNELAPI DECLSPEC_NORETURN VOID | KeBugCheckEx (IN ULONG BugCheckCode, IN ULONG_PTR BugCheckParameter1, IN ULONG_PTR BugCheckParameter2, IN ULONG_PTR BugCheckParameter3, IN ULONG_PTR BugCheckParameter4) |
NTKERNELAPI BOOLEAN | KeDeregisterBugCheckCallback (IN PKBUGCHECK_CALLBACK_RECORD CallbackRecord) |
NTKERNELAPI BOOLEAN | KeRegisterBugCheckCallback (IN PKBUGCHECK_CALLBACK_RECORD CallbackRecord, IN PKBUGCHECK_CALLBACK_ROUTINE CallbackRoutine, IN PVOID Buffer, IN ULONG Length, IN PUCHAR Component) |
NTKERNELAPI VOID | KeEnterKernelDebugger (VOID) |
VOID | KeDumpMachineState (IN PKPROCESSOR_STATE ProcessorState, IN PCHAR Buffer, IN PULONG_PTR BugCheckParameters, IN ULONG NumberOfParameters, IN PKE_BUGCHECK_UNICODE_TO_ANSI UnicodeToAnsiRoutine) |
VOID | KeContextFromKframes (IN PKTRAP_FRAME TrapFrame, IN PKEXCEPTION_FRAME ExceptionFrame, IN OUT PCONTEXT ContextFrame) |
VOID | KeContextToKframes (IN OUT PKTRAP_FRAME TrapFrame, IN OUT PKEXCEPTION_FRAME ExceptionFrame, IN PCONTEXT ContextFrame, IN ULONG ContextFlags, IN KPROCESSOR_MODE PreviousMode) |
VOID __cdecl | KeSaveStateForHibernate (IN PKPROCESSOR_STATE ProcessorState) |
VOID | KeCopyTrapDispatcher (VOID) |
BOOLEAN FASTCALL | KeInvalidAccessAllowed (IN PVOID TrapInformation OPTIONAL) |
NTKERNELAPI VOID | KeFlushCurrentTb (VOID) |
NTKERNELAPI VOID | KeFlushEntireTb (IN BOOLEAN Invalid, IN BOOLEAN AllProcessors) |
VOID | KeFlushMultipleTb (IN ULONG Number, IN PVOID *Virtual, IN BOOLEAN Invalid, IN BOOLEAN AllProcesors, IN PHARDWARE_PTE *PtePointer OPTIONAL, IN HARDWARE_PTE PteValue) |
HARDWARE_PTE | KeFlushSingleTb (IN PVOID Virtual, IN BOOLEAN Invalid, IN BOOLEAN AllProcesors, IN PHARDWARE_PTE PtePointer, IN HARDWARE_PTE PteValue) |
BOOLEAN | KeFreezeExecution (IN PKTRAP_FRAME TrapFrame, IN PKEXCEPTION_FRAME ExceptionFrame) |
KCONTINUE_STATUS | KeSwitchFrozenProcessor (IN ULONG ProcessorNumber) |
VOID | KeGetNonVolatileContextPointers (IN PKNONVOLATILE_CONTEXT_POINTERS NonVolatileContext) |
NTKERNELAPI VOID | KeSetDmaIoCoherency (IN ULONG Attributes) |
VOID | KeSetSystemTime (IN PLARGE_INTEGER NewTime, OUT PLARGE_INTEGER OldTime, IN BOOLEAN AdjustInterruptTime, IN PLARGE_INTEGER HalTimeToSet OPTIONAL) |
NTKERNELAPI BOOLEAN | KeAddSystemServiceTable (IN PULONG_PTR Base, IN PULONG Count OPTIONAL, IN ULONG Limit, IN PUCHAR Number, IN ULONG Index) |
NTKERNELAPI ULONGLONG | KeQueryInterruptTime (VOID) |
NTKERNELAPI VOID | KeQuerySystemTime (OUT PLARGE_INTEGER CurrentTime) |
NTKERNELAPI ULONG | KeQueryTimeIncrement (VOID) |
NTKERNELAPI KAFFINITY | KeQueryActiveProcessors (VOID) |
NTKERNELAPI VOID | KeSetTimeIncrement (IN ULONG MaximumIncrement, IN ULONG MimimumIncrement) |
VOID | KeThawExecution (IN BOOLEAN Enable) |
VOID | KeReturnToFirmware (IN FIRMWARE_REENTRY Routine) |
VOID | KeStartAllProcessors (VOID) |
VOID | KeBalanceSetManager (IN PVOID Context) |
VOID | KeSwapProcessOrStack (IN PVOID Context) |
NTKERNELAPI NTSTATUS | KeUserModeCallback (IN ULONG ApiNumber, IN PVOID InputBuffer, IN ULONG InputLength, OUT PVOID *OutputBuffer, OUT PULONG OutputLength) |
PVOID | KeSwitchKernelStack (IN PVOID StackBase, IN PVOID StackLimit) |
NTSTATUS | KeRaiseUserException (IN NTSTATUS ExceptionCode) |
NTKERNELAPI PCONFIGURATION_COMPONENT_DATA | KeFindConfigurationEntry (IN PCONFIGURATION_COMPONENT_DATA Child, IN CONFIGURATION_CLASS Class, IN CONFIGURATION_TYPE Type, IN PULONG Key OPTIONAL) |
NTKERNELAPI PCONFIGURATION_COMPONENT_DATA | KeFindConfigurationNextEntry (IN PCONFIGURATION_COMPONENT_DATA Child, IN CONFIGURATION_CLASS Class, IN CONFIGURATION_TYPE Type, IN PULONG Key OPTIONAL, IN PCONFIGURATION_COMPONENT_DATA *Resume) |
NTKERNELAPI VOID FASTCALL | KeSetSwapContextNotifyRoutine (IN PSWAP_CONTEXT_NOTIFY_ROUTINE NotifyRoutine) |
NTKERNELAPI VOID FASTCALL | KeSetThreadSelectNotifyRoutine (IN PTHREAD_SELECT_NOTIFY_ROUTINE NotifyRoutine) |
NTKERNELAPI VOID FASTCALL | KeSetTimeUpdateNotifyRoutine (IN PTIME_UPDATE_NOTIFY_ROUTINE NotifyRoutine) |
Variables | |
KAFFINITY | KeActiveProcessors |
LARGE_INTEGER | KeBootTime |
ULONGLONG | KeBootTimeBias |
ULONGLONG | KeInterruptTimeBias |
LIST_ENTRY | KeBugCheckCallbackListHead |
KSPIN_LOCK | KeBugCheckCallbackLock |
PGDI_BATCHFLUSH_ROUTINE | KeGdiFlushUserBatch |
PLOADER_PARAMETER_BLOCK | KeLoaderBlock |
ULONG | KeMaximumIncrement |
ULONG | KeMinimumIncrement |
CCHAR | KeNumberProcessors |
USHORT | KeProcessorArchitecture |
USHORT | KeProcessorLevel |
USHORT | KeProcessorRevision |
ULONG | KeFeatureBits |
CCHAR | KiFindFirstSetRight [256] |
PKPRCB | KiProcessorBlock [] |
ULONG | KiStackProtectTime |
KTHREAD_SWITCH_COUNTERS | KeThreadSwitchCounters |
ULONG | KeRegisteredProcessors |
ULONG | KeLicensedProcessors |
PULONG | KeServiceCountTable |
KSERVICE_TABLE_DESCRIPTOR | KeServiceDescriptorTable [NUMBER_SERVICE_TABLES] |
KSERVICE_TABLE_DESCRIPTOR | KeServiceDescriptorTableShadow [NUMBER_SERVICE_TABLES] |
volatile KSYSTEM_TIME | KeTickCount |
PVOID | KeUserApcDispatcher |
PVOID | KeUserCallbackDispatcher |
PVOID | KeUserExceptionDispatcher |
PVOID | KeRaiseUserExceptionDispatcher |
ULONG | KeTimeAdjustment |
ULONG | KeTimeIncrement |
BOOLEAN | KeTimeSynchronization |
|
|
|
Definition at line 76 of file ke.h. Referenced by main(). |
|
Definition at line 28 of file ke.h. Referenced by KeUpdateRunTime(), KiDecrementQuantum(), and main(). |
|
|
|
Definition at line 2496 of file ke.h. Referenced by KeFlushIoBuffers(), and KiInitializeKernel(). |
|
Definition at line 2497 of file ke.h. Referenced by KeFlushIoBuffers(). |
|
Definition at line 2498 of file ke.h. Referenced by KeFlushIoBuffers(), and KiInitializeKernel(). |
|
|
|
|
|
|
|
|
Value:
Definition at line 2293 of file ke.h. Referenced by KeFreezeExecution(), KeI386SetGdtSelector(), KeThawExecution(), KiFlushForwardProgressTbBuffer(), and KiInvalidateForwardProgressTbBuffer(). |
|
Definition at line 100 of file ke.h. Referenced by IoInitializeIrp(). |
|
|
|
|
Definition at line 1302 of file ke.h. Referenced by MiAccessCheck(), NtNotifyChangeMultipleKeys(), and PspExitThread(). |
|
|
|
|
Value:
Definition at line 1124 of file ke.h. Referenced by NtSetHighEventPair(). |
|
Value:
Definition at line 1720 of file ke.h. Referenced by NtSetHighWaitLowEventPair(). |
|
Value:
Definition at line 1129 of file ke.h. Referenced by NtSetLowEventPair(). |
|
Value:
Definition at line 1725 of file ke.h. Referenced by NtSetLowWaitHighEventPair(). |
|
Definition at line 1335 of file ke.h. Referenced by PspProcessDelete(). |
|
Value:
Definition at line 1730 of file ke.h. Referenced by NtWaitHighEventPair(). |
|
Value:
Definition at line 1737 of file ke.h. Referenced by NtWaitLowEventPair(). |
|
|
|
Value:
Definition at line 1537 of file ke.h. Referenced by KeLeaveCriticalRegion(). |
|
|
Definition at line 802 of file ke.h. Referenced by NtCreateChannel(). |
|
Definition at line 803 of file ke.h. Referenced by NtOpenChannel(). |
|
Definition at line 301 of file ke.h. Referenced by KeAddSystemServiceTable(), KiInitSystem(), and NtQuerySystemInformation(). |
|
Definition at line 35 of file ke.h. Referenced by KiFindReadyThread(), and main(). |
|
Definition at line 42 of file ke.h. Referenced by ExpBoostOwnerThread(), KeBoostCurrentThread(), KiScanReadyQueues(), and main(). |
|
|
|
|
|
|
|
|
|
|
|
|
|
Definition at line 36 of file ke.h. Referenced by KeInitializeProcess(), main(), PsChangeQuantumTable(), and PsSetProcessPriorityByClass(). |
|
Definition at line 79 of file ke.h. Referenced by KeInitializeThread(), KeWaitForMultipleObjects(), NtWaitForMultipleObjects(), and SmbTraceThreadEntry(). |
|
Definition at line 94 of file ke.h. Referenced by KeCheckForTimer(), KeSetSystemTime(), KiCalibrateTimeAdjustment(), KiChkTimerExpireSysDpc(), KiInitSystem(), and KiTimerExpiration(). |
|
Definition at line 84 of file ke.h. Referenced by KeDelayExecutionThread(), KeInitializeThread(), KeWaitForMultipleObjects(), and KeWaitForSingleObject(). |
|
Definition at line 29 of file ke.h. Referenced by KiAdjustQuantumThread(), KiUnwaitThread(), and main(). |
|
|
|
|
|
Referenced by NtCreateChannel(). |
|
|
|
Referenced by KeReturnToFirmware(). |
|
Referenced by KeInitializeApc(). |
|
|
|
|
|
Referenced by KiScanBugCheckCallbackList(). |
|
Referenced by KeInitializeDeviceQueue(). |
|
Referenced by KeInsertByKeyDeviceQueue(). |
|
|
|
Referenced by KeInitializeEventPair(). |
|
|
|
|
|
|
|
|
|
|
|
|
|
|
|
|
|
Referenced by KiProcessProfileList(). |
|
Referenced by NtCreateIoCompletion(). |
|
|
|
|
|
Referenced by KeStartAllProcessors(). |
|
|
|
|
|
Referenced by RawInputThread(). |
|
Referenced by KeBalanceSetManager(). |
|
Referenced by KeWaitForMultipleObjects(), and KeWaitForSingleObject(). |
|
Referenced by MiSweepCacheMachineDependent(). |
|
|
|
Referenced by NtOpenChannel(). |
|
|
|
Definition at line 2275 of file ke.h. Referenced by PsEstablishWin32Callouts(). |
|
Referenced by KeRemoveQueueApc(). |
|
Referenced by KeDeregisterBugCheckCallback(). |
|
Definition at line 2149 of file ke.h. Referenced by KeRegisterBugCheckCallback(). |
|
|
|
|
|
Referenced by KeInitializeDeviceQueue(). |
|
Referenced by KeInsertDeviceQueue(). |
|
Definition at line 2216 of file ke.h. Referenced by KiDumpParameterImages(). |
|
|
|
Referenced by KeInitializeEventPair(). |
|
Definition at line 477 of file ke.h. Referenced by KeInitializeInterrupt(). |
|
|
|
Referenced by KeReleaseMutex(). |
|
Referenced by KeStartAllProcessors(). |
|
Referenced by KiProcessProfileList(). |
|
Referenced by KiUnwaitThread(). |
|
|
|
Definition at line 440 of file ke.h. Referenced by KeInitializeInterrupt(). |
|
Referenced by NtQuerySystemInformation(). |
|
Definition at line 367 of file ke.h. Referenced by KiInitializeKernel(), PsCreateSystemThread(), PspCreateThread(), SmbTraceStart(), xxxInitInput(), and xxxInitTerminal(). |
|
Definition at line 379 of file ke.h. Referenced by KiInitializeContextThread(), and KiInitializeKernel(). |
|
Referenced by KeStartAllProcessors(). |
|
|
|
Referenced by KiChkTimerExpireSysDpc(). |
|
|
|
|
|
|
|
|
|
|
|
Referenced by KeInitializeEvent(). |
|
|
|
|
|
|
|
|
|
|
|
|
|
|
|
|
|
|
|
|
|
|
|
|
|
|
|
|
|
Definition at line 805 of file ke.h.
|
|
Definition at line 2611 of file ke.h.
|
|
Definition at line 153 of file ke.h.
|
|
Definition at line 2139 of file ke.h.
|
|
Definition at line 165 of file ke.h.
|
|
Definition at line 122 of file ke.h.
|
|
Definition at line 176 of file ke.h.
|
|
Definition at line 188 of file ke.h.
|
|
Definition at line 203 of file ke.h.
|
|
Definition at line 2824 of file ke.h.
|
|
Definition at line 2820 of file ke.h.
|
|
Definition at line 353 of file ke.h. Referenced by KdpReportExceptionStateChange(), KdpReportLoadSymbolsStateChange(), KdpSendWaitContinue(), and KiFreezeTargetExecution().
|
|
|
|
|
|
|
|
Definition at line 815 of file ke/miscc.c. References _KSERVICE_TABLE_DESCRIPTOR::Base, _KSERVICE_TABLE_DESCRIPTOR::Count, Count, FALSE, Index, KeServiceDescriptorTable, KeServiceDescriptorTableShadow, _KSERVICE_TABLE_DESCRIPTOR::Limit, NULL, _KSERVICE_TABLE_DESCRIPTOR::Number, NUMBER_SERVICE_TABLES, PAGED_CODE, and TRUE.
|
|
Definition at line 365 of file thredobj.c. References ALERT_INCREMENT, ASSERT, ASSERT_THREAD, DISPATCH_LEVEL, FALSE, KernelMode, KiLockDispatcherDatabase, KiUnlockDispatcherDatabase(), KiUnwaitThread(), KiWaitTest(), RESUME_INCREMENT, TRUE, and Waiting. Referenced by NtAlertResumeThread().
|
|
Definition at line 281 of file thredobj.c. References ALERT_INCREMENT, ASSERT, ASSERT_THREAD, DISPATCH_LEVEL, FALSE, KiLockDispatcherDatabase, KiUnlockDispatcherDatabase(), KiUnwaitThread(), TRUE, and Waiting. Referenced by NtAlertThread().
|
|
|
Definition at line 142 of file balmgr.c. References ExAdjustLookasideDepth(), EXECUTION_TIME_LIMITS_PERIOD, Executive, FALSE, KeGetCurrentThread, KeInitializeTimer(), KernelMode, KeSetEvent(), KeSetPriorityThread(), KeSetTimer(), KeWaitForMultipleObjects(), KiLockDispatcherDatabase, KiScanReadyQueues(), KiStackOutSwapRequest, KiStackProtectTime, KiSwapEvent, KiUnlockDispatcherDatabase(), KWAIT_BLOCK, MaximumObject, MmQuerySystemSize(), MmSmallSystem, MmWorkingSetManager(), MmWorkingSetManagerEvent, NTSTATUS(), NULL, PERIODIC_INTERVAL, PsEnforceExecutionTimeLimits(), SMALL_SYSTEM_STACK_PROTECT_TIME, STACK_PROTECT_TIME, STACK_SCAN_PERIOD, Status, TimerExpiration, TRUE, and WorkingSetManagerEvent. Referenced by MmInitSystem().
|
|
Definition at line 154 of file waitsup.c. References _KTHREAD::ApcState, _KTHREAD::BasePriority, _KTHREAD::DecrementCount, KeGetCurrentThread, KeSetPriorityThread(), KiLockDispatcherDatabase, KiUnlockDispatcherDatabase(), _KTHREAD::Priority, _KTHREAD::PriorityDecrement, _KAPC_STATE::Process, _KTHREAD::Quantum, ROUND_TRIP_DECREMENT_COUNT, and _KPROCESS::ThreadQuantum.
|
|
Definition at line 459 of file thredobj.c. References ASSERT, DISPATCH_LEVEL, Increment, KiBoostPriorityThread, KiLockDispatcherDatabase, and KiUnlockDispatcherDatabase(). Referenced by ExpWaitForResourceDdk(), NtReadFile(), NtSetInformationProcess(), and VdmDispatchInterrupts().
|
|
|
Definition at line 428 of file bugcheck.c. References Buffer, DATA_BUS_ERROR, DbgPrint, ExPoolCodeEnd, ExPoolCodeStart, FALSE, HalRebootRoutine, HalReturnToFirmware(), HIGH_LEVEL, INBV_DISPLAY_STRING_FILTER, InbvAcquireDisplayOwnership(), InbvDisplayString(), InbvEnableDisplayString(), InbvInstallDisplayStringFilter(), InbvIsBootDriverInstalled(), InbvResetDisplay(), InbvSetScrollRegion(), InbvSetTextColor(), InbvSolidColorFill(), IoWriteCrashDump(), IPI_FREEZE, IRQL_NOT_LESS_OR_EQUAL, IS_SYSTEM_ADDRESS, KdDebuggerDataBlock, KdDebuggerEnabled, KdDebuggerNotPresent, KdInitSystem(), KdPitchDebugger, KeActiveProcessors, KeBugCheckCount, KeBugCheckUnicodeToAnsi(), KeGetBugMessageText(), KeGetCurrentPrcb, KeGetCurrentThread, KeRaiseIrql(), KeStallExecutionProcessor(), KiBugCheckData, KiBugCheckDebugBreak(), KiBugCheckDriver, KiDisableInterrupts(), KiDumpParameterImages(), KiHardwareTrigger, KiIpiSend(), KiPcToFileHeader(), KiSaveProcessorControlState(), KiScanBugCheckCallbackList(), KMODE_EXCEPTION_NOT_HANDLED, MmIsHydraAddress(), MmIsSpecialPoolAddressFree(), MmLocateUnloadedDriver(), MmPoolCodeEnd, MmPoolCodeStart, MmPteCodeEnd, MmPteCodeStart, MmSpecialPoolEnd, MmSpecialPoolStart, NULL, POWER_FAILURE_SIMULATE, sprintf(), _KTHREAD::Teb, TRUE, and UNEXPECTED_KERNEL_MODE_TRAP. Referenced by CmBootLastKnownGood(), CmGetSystemControlValues(), CmGetSystemDriverList(), CmInitSystem1(), CmpCheckLockExceptionFilter(), CmpHiveRootSecurityDescriptor(), CmpInitializeCache(), CmpInitializeHiveList(), CmpInitializeSystemHive(), CmpReleaseGlobalQuota(), CmpSecurityMethod(), CmpWorker(), DrvDriverFailure(), ExAllocatePoolSanityChecks(), ExFreePoolSanityChecks(), ExFreePoolWithTag(), ExInitializeRegion(), ExInterlockedExtendRegion(), ExpCheckForWorker(), ExpSystemErrorHandler(), ExpWorkerThread(), ExReleaseResourceLite(), ExUnlockHandleTableEntry(), FsRtlWorkerThread(), HvRefreshHive(), InitializePool(), IoAssignResources(), IoBuildPoDeviceNotifyList(), IoCancelIrp(), IoInitSystem(), IopDestroyDeviceNode(), IopDriverCorrectnessThrowBugCheck(), IopEnumerateDevice(), IopfCallDriver(), IopFreeIrp(), IopInitializeBootDrivers(), IopMarkBootPartition(), IopMountVolume(), IopProcessNewDeviceNode(), IopProcessRelation(), IopStartAndEnumerateDevice(), IoReportResourceForDetection(), IoReportResourceUsage(), IovBuildAsynchronousFsdRequest(), IovBuildDeviceIoControlRequest(), IovCallDriver(), IovCompleteRequest(), IovFreeIrpPrivate(), IovInitializeTimer(), IovpCompleteRequest(), IovSpecialIrpCallDriver(), KdpCauseBugCheck(), KeAttachProcess(), KeBugCheck(), KeBusError(), KeCheckForTimer(), KeForceAttachProcess(), KeRemoveQueue(), KeRundownThread(), KeStackAttachProcess(), KfSanityCheckLowerIrql(), KfSanityCheckRaiseIrql(), KiDeliverApc(), KiDispatchException(), KiEmulateFloat(), KiGeneralExceptions(), KiIA32ExceptionNoDevice(), KiIA32ExceptionPanic(), KiIA32InterceptInstruction(), KiInitializeKernel(), KiMemoryFault(), KiNatExceptions(), KiRequestSoftwareInterrupt(), MiAddMdlTracker(), MiAllocatePoolPages(), MiAllocateSpecialPool(), MiCheckSessionPoolAllocations(), MiCleanSection(), MiCloneProcessAddressSpace(), MiConvertToLoaderVirtual(), MiDecrementCloneBlockReference(), MiDecrementReferenceCount(), MiDecrementShareCount(), MiDeletePte(), MiDeleteSystemPagableVm(), MiEliminateWorkingSetEntry(), MiEnsureAvailablePageOrWait(), MiEnsureAvailablePagesInFreeDescriptor(), MiFreeMdlTracker(), MiFreePoolPages(), MiFreeSessionSpaceMap(), MiGetNextPhysicalPage(), MiHandleForkTransitionPte(), MiInitializeCopyOnWritePfn(), MiInitializePfn(), MiInitializeReadInProgressPfn(), MiInitializeTransitionPfn(), MiInitMachineDependent(), MiInsertPageInList(), MiInsertStandbyListAtFront(), MiLocateWsle(), MiLookupWsleHashIndex(), MiMakeOutswappedPageResident(), MiMakeSystemAddressValid(), MiMakeSystemAddressValidPfn(), MiMakeSystemAddressValidPfnSystemWs(), MiMakeSystemAddressValidPfnWs(), MiReleaseSystemPtes(), MiRemoveFromSystemSpace(), MiRemovePageByColor(), MiRemovePageFromList(), MiRemovePteTracker(), MiRemoveWsle(), MiReserveSystemPtes(), MiReserveSystemPtes2(), MiResolveMappedFileFault(), MiUnlinkPageFromList(), MiVerifyingDriverUnloading(), MiWaitForInPageComplete(), MmAccessFault(), MmCleanProcessAddressSpace(), MmFreeLoaderBlock(), MmFreeSpecialPool(), MmInPageKernelStack(), MmLockPagableDataSection(), MmMapViewInSystemCache(), MmPurgeSection(), MmUnloadSystemImage(), MmUnlockCachedPage(), MmUnlockPages(), MmZeroPageThread(), MxGetNextPage(), NtClose(), NtNotifyChangeMultipleKeys(), NtUserInitialize(), PsLocateSystemDll(), PspExitThread(), PspInitializeSystemDll(), PspInitPhase0(), PspUnhandledExceptionInSystemThread(), VerifierExAcquireFastMutex(), VerifierExAcquireFastMutexUnsafe(), VerifierExAcquireResourceExclusive(), VerifierExReleaseFastMutex(), VerifierExReleaseFastMutexUnsafe(), VerifierExReleaseResource(), VerifierExTryToAcquireFastMutex(), VerifierFreeTrackedPool(), VerifierKeReleaseSpinLock(), VerifierMapIoSpace(), VerifierMapLockedPages(), VerifierMapLockedPagesSpecifyCache(), VerifierProbeAndLockPages(), VerifierProbeAndLockProcessPages(), VerifierProbeAndLockSelectedPages(), VerifierSetEvent(), VerifierUnlockPages(), VerifierUnmapIoSpace(), VerifierUnmapLockedPages(), ViReleasePoolAllocation(), xHalAssignSlotResources(), and xHalTranslateBusAddress().
|
|
Definition at line 157 of file timerobj.c. References ASSERT, ASSERT_TIMER, DISPATCH_LEVEL, FALSE, KiLockDispatcherDatabase, KiRemoveTreeTimer, and KiUnlockDispatcherDatabase(). Referenced by ExpDeleteTimer(), ExTimerRundown(), NtCancelTimer(), NtSetTimer(), and Win32kNtUserCleanup().
|
|
Definition at line 467 of file timerobj.c. References BlockSize, _KDPC::DeferredRoutine, _KTIMER::Dpc, End, Index, KeBugCheckEx(), KiLockDispatcherDatabase, KiTimerTableListHead, KiUnlockDispatcherDatabase(), NULL, Start, and TIMER_TABLE_SIZE. Referenced by ExFreePoolSanityChecks(), MmUnloadSystemImage(), and VerifierKeInitializeTimerEx().
|
|
Definition at line 124 of file timerobj.c. References ASSERT_TIMER.
|
|
Definition at line 515 of file thredobj.c. References _KTHREAD::Affinity, ASSERT, DISPATCH_LEVEL, KeGetCurrentThread, KiLockDispatcherDatabase, KiUnlockDispatcherDatabase(), and _KTHREAD::NextProcessor.
|
|
Definition at line 154 of file alpha/intobj.c. References CHAR, _KINTERRUPT::DispatchAddress, _KINTERRUPT::DispatchCode, FALSE, HalEnableSystemInterrupt(), HIGH_LEVEL, _KINTERRUPT::InterruptListEntry, KeLowerIrql(), KeNumberProcessors, KeRaiseIrql(), KeRevertToUserAffinityThread(), KeSetSystemAffinityThread(), KiChainedDispatch(), KiFloatingDispatch(), KiInterruptDispatchRaise(), KiInterruptDispatchSame(), KiLockDispatcherDatabase, KiUnlockDispatcherDatabase(), max, _KINTERRUPT::Mode, _KINTERRUPT::ShareVector, SYNCH_LEVEL, and TRUE. Referenced by IoConnectInterrupt().
|
|
Definition at line 104 of file alpha/exceptn.c. References CONTEXT_CONTROL, CONTEXT_FLOATING_POINT, CONTEXT_INTEGER, KeGetCurrentThread, KernelMode, and KiBreakPoints. Referenced by Ke386SetIOPL(), KiDispatchException(), KiInitializeUserApc(), KiSaveProcessorState(), and PspGetContext().
|
|
Definition at line 258 of file alpha/exceptn.c. References CONTEXT_CONTROL, CONTEXT_FLOATING_POINT, CONTEXT_INTEGER, KeGetCurrentThread, KeGetPcr, and KernelMode. Referenced by Ke386SetIOPL(), KiContinue(), KiContinuePreviousModeUser(), KiDispatchException(), KiInitializeContextThread(), KiRaiseException(), KiRestoreProcessorState(), and PspSetContext().
|
|
|
|
Definition at line 140 of file wait.c. References _KTHREAD::Alertable, APC_LEVEL, _KTHREAD::ApcState, ASSERT, _KTHREAD::BasePriority, DelayExecution, DISPATCH_LEVEL, _KTIMER::DueTime, FALSE, _KTIMER::Header, KeGetCurrentPrcb, KeGetCurrentThread, _KAPC_STATE::KernelApcPending, KiActivateWaiterQueue(), KiComputeWaitInterval(), KiFindReadyThread(), KiInsertTreeTimer(), KiInsertWaitList, KiLockDispatcherDatabase, KiReadyThread(), KiSetPriorityThread(), KiSwapThread(), KiUnlockDispatcherDatabase(), _KTHREAD::NextProcessor, _KWAIT_BLOCK::NextWaitBlock, NTSTATUS(), NULL, _KTHREAD::Preempted, _KTHREAD::Priority, _KTHREAD::PriorityDecrement, _KAPC_STATE::Process, _KTHREAD::Quantum, _KTHREAD::Queue, _KTHREAD::State, TestForAlertPending, _KPROCESS::ThreadQuantum, _KTHREAD::Timer, TIMER_WAIT_BLOCK, TRUE, _KTHREAD::WaitBlock, _KTHREAD::WaitBlockList, Waiting, _KTHREAD::WaitIrql, _KWAIT_BLOCK::WaitListEntry, _DISPATCHER_HEADER::WaitListHead, _KTHREAD::WaitMode, _KTHREAD::WaitNext, _KTHREAD::WaitReason, _KTHREAD::WaitStatus, and _KTHREAD::WaitTime. Referenced by CcPurgeCacheSection(), IoCancelThreadIo(), IopCancelAlertedRequest(), IopStartNetworkForRemoteBoot(), KiInitMachineDependent(), MemPrintFlush(), MemPrintWriteThread(), MiAllocateContiguousMemory(), MiCheckControlAreaStatus(), MiCheckSystemTrimEndCriteria(), MiCleanSection(), MiCloneProcessAddressSpace(), MiDispatchFault(), MiEmptyWorkingSet(), MiFlushAllPages(), MiFlushSectionInternal(), MiMakeOutswappedPageResident(), MiModifiedPageWriter(), MiModifiedPageWriterWorker(), MiPurgeImageSection(), MiRemoveUnusedSegments(), MiResolveProtoPteFault(), MiWriteComplete(), MmAccessFault(), MmCopyToCachedPage(), MmFlushSection(), MmFlushVirtualMemory(), MmGatherMemoryForHibernate(), MmGetSystemRoutineAddress(), MmRemovePhysicalMemory(), MmShutdownSystem(), MmWorkingSetManager(), NtCancelIoFile(), NtCreateSection(), NtDelayExecution(), Reader(), ReaderTurnedWriter(), UserBeep(), UserSleep(), Writer(), and xxxLW_LoadFonts().
|
|
Definition at line 1064 of file bugcheck.c. References BufferEmpty, BufferInserted, FALSE, HIGH_LEVEL, KeBugCheckCallbackLock, KeLowerIrql(), KeRaiseIrql(), PKBUGCHECK_CALLBACK_RECORD, and TRUE.
|
|
Definition at line 405 of file procobj.c. References APC_LEVEL, _KAPC_STATE::ApcListHead, _KTHREAD::ApcState, _KTHREAD::ApcStateIndex, _KTHREAD::ApcStatePointer, ASSERT, BALANCE_INCREMENT, DISPATCH_LEVEL, FALSE, _KEVENT::Header, KeBugCheck(), KeGetCurrentThread, _KAPC_STATE::KernelApcInProgress, _KAPC_STATE::KernelApcPending, KernelMode, KiLockDispatcherDatabase, KiMoveApcState(), KiProcessOutSwapListHead, KiRequestSoftwareInterrupt(), KiSwapEvent, KiSwapProcess(), KiUnlockDispatcherDatabase(), KiWaitTest(), NULL, _KAPC_STATE::Process, ProcessInTransition, _KTHREAD::SavedApcState, _DISPATCHER_HEADER::SignalState, _KPROCESS::StackCount, _KPROCESS::State, _KPROCESS::SwapListEntry, _KPROCESS::ThreadListHead, TRUE, UserMode, and _DISPATCHER_HEADER::WaitListHead. Referenced by _GetComboBoxInfo(), _GetListBoxInfo(), CheckWHFBits(), MiCloneProcessAddressSpace(), MiCreatePebOrTeb(), MiDoMappedCopy(), MiDoPoolCopy(), MiEmptyAllWorkingSetsWorker(), MiGetWorkingSetInfo(), MiLoadImageSection(), MiLoadSystemImage(), MmAssignProcessToJob(), MmCreatePeb(), MmCreateTeb(), MmDeleteTeb(), MmFlushVirtualMemory(), MmInitializeProcessAddressSpace(), MmMapViewOfSection(), MmProbeAndLockProcessPages(), MmSetBankedSection(), MmSetMemoryPriorityProcess(), MmUnmapViewOfSection(), MmWorkingSetManager(), NtAllocateUserPhysicalPages(), NtAllocateVirtualMemory(), NtDuplicateObject(), NtFlushInstructionCache(), NtFreeUserPhysicalPages(), NtFreeVirtualMemory(), NtLockVirtualMemory(), NtProtectVirtualMemory(), NtQueryVirtualMemory(), NtSetInformationJobObject(), NtSetInformationProcess(), NtUnlockVirtualMemory(), ObReferenceObjectByHandle(), PsAssignImpersonationToken(), PspAddProcessToJob(), PspCreateProcess(), PspSetQuotaLimits(), SepRmCallLsa(), SetProcessFlags(), SmbTraceCompleteRdr(), SmbTraceDisconnect(), SmbTraceStop(), xxxCheckImeShowStatus(), xxxCreateDisconnectDesktop(), xxxCreateWindowStation(), xxxGetThreadDesktop(), xxxImmActivateAndUnloadThreadsLayout(), xxxMinMaximize(), xxxNotifyImeShowStatus(), xxxSendMessageToUI(), and zzzSetWindowsHookEx().
|
|
Definition at line 574 of file thredobj.c. References ASSERT, ASSERT_THREAD, DISPATCH_LEVEL, FALSE, KiLockDispatcherDatabase, and KiUnlockDispatcherDatabase(). Referenced by PspExitThread().
|
|
Definition at line 298 of file alpha/intobj.c. References _KINTERRUPT::DispatchAddress, _KINTERRUPT::DispatchCode, FALSE, HalDisableSystemInterrupt(), _KINTERRUPT::InterruptListEntry, KeLowerIrql(), KeRaiseIrql(), KeRevertToUserAffinityThread(), KeSetSystemAffinityThread(), KeSweepIcache(), KiChainedDispatch(), KiFloatingDispatch(), KiInterruptDispatchRaise(), KiInterruptDispatchSame(), KiLockDispatcherDatabase, KiUnlockDispatcherDatabase(), max, SYNCH_LEVEL, and TRUE. Referenced by IoDisconnectInterrupt(), and KeConnectInterrupt().
|
|
|
|
Definition at line 631 of file thredobj.c. References ASSERT, ASSERT_THREAD, DISPATCH_LEVEL, KiLockDispatcherDatabase, KiUnlockDispatcherDatabase(), and TRUE. Referenced by PspCreateThread().
|
|
Definition at line 1015 of file bugcheck.c. References FALSE, HIGH_LEVEL, KdDebuggerEnabled, KdInitSystem(), KdPitchDebugger, KeBugCheckCount, KeRaiseIrql(), KiBugCheckDebugBreak(), KiDisableInterrupts(), KiHardwareTrigger, and NULL.
|
|
Definition at line 34 of file config.c. References KeFindConfigurationNextEntry(), Key, and NULL. Referenced by CmpInitializeHardwareConfiguration().
|
|
Definition at line 62 of file config.c. References _CONFIGURATION_COMPONENT_DATA::Child, _CONFIGURATION_COMPONENT::Class, _CONFIGURATION_COMPONENT_DATA::ComponentEntry, Key, _CONFIGURATION_COMPONENT::Key, NULL, _CONFIGURATION_COMPONENT_DATA::Sibling, and _CONFIGURATION_COMPONENT::Type. Referenced by KeFindConfigurationEntry().
|
|
|
Definition at line 86 of file alpha/flushtb.c. References ASSERT, IPI_INSTRUMENT_COUNT, KeFlushCurrentTb(), KeGetCurrentPrcb, KeLowerIrql(), and SYNCH_LEVEL. Referenced by MiCheckVirtualAddress(), MiDownShareCountFlushEntireTb(), MiFlushPteList(), MiFlushUserPhysicalPteList(), MiHandleBankedSection(), MiInitMachineDependent(), MiMapBBTMemory(), MiMapLockedPagesInUserSpace(), MiMapPageInHyperSpace(), MiMapSinglePage(), MiMapViewOfPhysicalSection(), MiReleaseSystemPtes(), MiRemoveMappedView(), MiReserveSystemPtes(), MiResolveMappedFileFault(), MmAllocateNonCachedMemory(), MmFreeLoaderBlock(), MmMapIoSpace(), MmMapLockedPagesSpecifyCache(), MmMapUserAddressesToPage(), MmMapViewInSystemCache(), MmOutPageKernelStack(), MmSetAddressRangeModified(), and MmSetBankedSection().
|
|
Definition at line 231 of file alpha/flushtb.c. References ASSERT, DISPATCH_LEVEL, Index, IPI_INSTRUMENT_COUNT, KeGetCurrentPrcb, KiFlushSingleTb(), and Virtual. Referenced by MiFlushPteList(), MiFlushUserPhysicalPteList(), MmOutPageKernelStack(), and MmSetAddressRangeModified().
|
|
Definition at line 138 of file apcobj.c. References ASSERT, DISPATCH_LEVEL, FALSE, _KAPC::Inserted, KiLockDispatcherDatabase, KiUnlockDispatcherDatabase(), NULL, and PKAPC. Referenced by PspExitThread().
|
|
Definition at line 420 of file alpha/flushtb.c. References ASSERT, DISPATCH_LEVEL, IPI_INSTRUMENT_COUNT, KeGetCurrentPrcb, KiFlushSingleCallData, KiFlushSingleTb(), RECORD_CALL_DATA, and Virtual. Referenced by Ki386UseSynchronousTbFlush(), MiCopyOnWrite(), MiDeletePte(), MiEliminateWorkingSetEntry(), MiEnablePagingOfDriverAtInit(), MiFlushDirtyBitsToPfn(), MiFlushPteList(), MiFlushTbAndCapture(), MiFlushUserPhysicalPteList(), MiFreeNonPagedPool(), MiInitMachineDependent(), MiMapPageToZeroInHyperSpace(), MiMapSinglePage(), MiProtectFreeNonPagedPool(), MiProtectSpecialPool(), MiResetVirtualMemory(), MiSetPageModified(), MiSetPagingOfDriver(), MiSetSystemCodeProtection(), MiUnmapImageHeaderInHyperSpace(), MiUnmapLockedPagesInUserSpace(), MmFreeSpecialPool(), MmMapUserAddressesToPage(), MmRemovePhysicalMemory(), MmSetAddressRangeModified(), and MmSetPageProtection().
|
|
|
|
Definition at line 688 of file thredobj.c. References ASSERT, ASSERT_THREAD, DISPATCH_LEVEL, KiLockDispatcherDatabase, KiUnlockDispatcherDatabase(), KiWaitTest(), and RESUME_INCREMENT. Referenced by NtTerminateProcess(), NtTerminateThread(), PspExitNormalApc(), PspExitThread(), and PspTerminateProcess().
|
|
Definition at line 757 of file thredobj.c. References _KTHREAD::ApcState, ASSERT, DISPATCH_LEVEL, FALSE, _KTHREAD::FreezeCount, _KSEMAPHORE::Header, KeEnterCriticalRegion, KeGetCurrentThread, KiInsertQueueApc(), KiLockDispatcherDatabase, KiUnlockDispatcherDatabase(), NULL, _KAPC_STATE::Process, RESUME_INCREMENT, _DISPATCHER_HEADER::SignalState, _KTHREAD::SuspendApc, _KTHREAD::SuspendCount, _KTHREAD::SuspendSemaphore, _ETHREAD::ThreadListEntry, and _KPROCESS::ThreadListHead. Referenced by DbgkpSuspendProcess().
|
|
Definition at line 55 of file ke/debug.c. References ClearMember, Count, FALSE, FREEZE_ACTIVE, FREEZE_BACKUP, FREEZE_FROZEN, FREEZE_OWNER, FREEZE_SKIPPED_PROCESSOR, FrozenState, HIGH_LEVEL, IPI_FREEZE, KeActiveProcessors, KeFindFirstSetRightMember, KeGetCurrentPrcb, KeRaiseIrql(), KeStallExecutionProcessor(), KiDisableInterrupts(), KiFreezeExecutionLock, KiFreezeFlag, KiFreezeLockBackup, KiFreezeOwner, KiIpiSend(), KiIpiServiceRoutine(), KiOldIrql, KiProcessorBlock, KiRestoreInterrupts(), KiTryToAcquireSpinLock(), TARGET_FROZEN, and TRUE. Referenced by KdEnterDebugger().
|
|
Definition at line 97 of file bugcheck.c. References Buffer, EXCEPTION_EXECUTE_HANDLER, FALSE, InbvDisplayString(), MmMakeKernelResourceSectionWritable(), NULL, strlen(), TRUE, and USHORT. Referenced by IopGetDumpStack(), and KeBugCheckEx().
|
|
|
|
|
|
Definition at line 40 of file devquobj.c. References DeviceQueueObject, FALSE, KDEVICE_QUEUE, KeInitializeSpinLock(), and PKDEVICE_QUEUE. Referenced by IoCreateController(), and IoCreateDevice().
|
|
Definition at line 39 of file dpcobj.c. References DpcObject, MediumImportance, NULL, PKDEFERRED_ROUTINE, and PRKDPC. Referenced by CcInitializeCacheManager(), CmpWorker(), IoInitSystem(), IopErrorLogQueueRequest(), IovpInternalDeferredCompletion(), KdInitSystem(), KiInitializeKernel(), KiInitSystem(), MiInitializeSpecialPoolCriteria(), MmInitSystem(), NtCreateTimer(), and VdmpDelayInterrupt().
|
|
Definition at line 96 of file eventobj.c. References EventPairObject, FALSE, KeInitializeEvent, KEVENT_PAIR, PKEVENT_PAIR, and USHORT. Referenced by NtCreateEventPair().
|
|
Definition at line 32 of file alpha/intobj.c. References FALSE, and InterruptObject. Referenced by IoConnectInterrupt().
|
|
Definition at line 40 of file mutntobj.c. References FALSE, KeGetCurrentThread, KiLockDispatcherDatabase, KiUnlockDispatcherDatabase(), _KTHREAD::MutantListHead, MutantObject, NULL, and TRUE. Referenced by MmInitSystem(), NtCreateMutant(), and ObInitSystem().
|
|
|
|
Definition at line 63 of file procobj.c. References ProcessInMemory, ProcessObject, and THREAD_QUANTUM. Referenced by KiInitializeKernel(), and PspCreateProcess().
|
|
Definition at line 69 of file profobj.c. References ASSERT, FALSE, KeActiveProcessors, NULL, and ProfileObject. Referenced by NtStartProfile().
|
|
Definition at line 36 of file queueobj.c. References Count, KeNumberProcessors, and QueueObject. Referenced by ExpWorkerInitialization(), FsRtlInitializeWorkerThread(), and NtCreateIoCompletion().
|
|
Definition at line 39 of file semphobj.c. References Count, and SemaphoreObject. Referenced by DoResourceTest(), ExAcquireResourceSharedLite(), ExAcquireSharedStarveExclusive(), ExAcquireSharedWaitForExclusive(), ExInitializeResource(), ExReinitializeResourceLite(), FsRtlInitSystem(), InitializePool(), IoInitSystem(), KeInitializeThread(), LpcpInitializePortQueue(), MiSectionInitialization(), NtCreateSemaphore(), obtest(), PspCreateThread(), and SmbTraceThreadEntry().
|
|
|
Definition at line 43 of file thredobj.c. References FALSE, _KTIMER::Header, Index, Initialized, KeInitializeApc(), KeInitializeSemaphore(), KeInitializeSpinLock(), KeInitializeTimer(), KeNumberProcessors, KernelMode, KeServiceDescriptorTable, KiInitializeContextThread(), KiLockDispatcherDatabase, KiSuspendNop(), KiSuspendThread(), KiUnlockDispatcherDatabase(), L, NULL, _KWAIT_BLOCK::Object, OriginalApcEnvironment, PKKERNEL_ROUTINE, PKRUNDOWN_ROUTINE, THREAD_WAIT_OBJECTS, ThreadObject, TIMER_WAIT_BLOCK, TRUE, UserMode, _KWAIT_BLOCK::WaitKey, _KWAIT_BLOCK::WaitListEntry, _DISPATCHER_HEADER::WaitListHead, and _KWAIT_BLOCK::WaitType. Referenced by KiInitializeKernel(), and PspCreateThread().
|
|
Definition at line 43 of file timerobj.c. References KeInitializeTimerEx(). Referenced by CcInitializeCacheManager(), CmpWorker(), ExpWorkerThreadBalanceManager(), IopErrorLogQueueRequest(), KdInitSystem(), KeBalanceSetManager(), KeInitializeThread(), MiInitializeSpecialPoolCriteria(), RawInputThread(), and VdmpDelayInterrupt().
|
|
Definition at line 75 of file timerobj.c. References FALSE, NULL, and TimerNotificationObject. Referenced by IoInitSystem(), IovpInternalDeferredCompletion(), KeInitializeTimer(), MmInitSystem(), NtCreateTimer(), RawInputThread(), and VerifierKeInitializeTimerEx().
|
|
Definition at line 41 of file kiinit.c. References FALSE, Initialized, KiChannelInitialization(), KiInitMachineDependent(), and TRUE.
|
|
Definition at line 145 of file devquobj.c. References ASSERT, ASSERT_DEVICE_QUEUE, DISPATCH_LEVEL, FALSE, KDEVICE_QUEUE_ENTRY, _KDEVICE_QUEUE_ENTRY::SortKey, and TRUE. Referenced by IoStartPacket().
|
|
Definition at line 83 of file devquobj.c. References ASSERT, ASSERT_DEVICE_QUEUE, DISPATCH_LEVEL, FALSE, PKDEVICE_QUEUE_ENTRY, and TRUE. Referenced by IoAllocateController(), and IoStartPacket().
|
|
Definition at line 181 of file queueobj.c. References ASSERT, ASSERT_QUEUE, DISPATCH_LEVEL, KiInsertQueue(), KiLockDispatcherDatabase, KiUnlockDispatcherDatabase(), and TRUE.
|
|
Definition at line 124 of file queueobj.c. References ASSERT, ASSERT_QUEUE, DISPATCH_LEVEL, FALSE, KiInsertQueue(), KiLockDispatcherDatabase, and KiUnlockDispatcherDatabase(). Referenced by ExQueueWorkItem(), FsRtlpPostStackOverflow(), IopCompleteRequest(), and IoSetIoCompletion().
|
|
Definition at line 217 of file apcobj.c. References _KTHREAD::ApcQueueable, ASSERT, ASSERT_APC, DISPATCH_LEVEL, FALSE, Increment, KiInsertQueueApc(), KiLockDispatcherDatabase, and KiUnlockDispatcherDatabase(). Referenced by CmpPostNotify(), ExpTimerDpcRoutine(), IopCompleteRequest(), IoRaiseHardError(), IoRaiseInformationalHardError(), KeSetAutoAlignmentThread(), NtGetContextThread(), NtQueueApcThread(), NtSetContextThread(), PspExitNormalApc(), PspTerminateThreadByPointer(), and PspUserThreadStartup().
|
|
Definition at line 89 of file dpcobj.c. References ASSERT_DPC, DISPATCH_LEVEL, FALSE, HIGH_LEVEL, HighImportance, Index, IPI_DPC, KeGetCurrentPrcb, KeLowerIrql(), KeRaiseIrql(), KiIpiSend(), KiProcessorBlock, KiRequestSoftwareInterrupt(), Lock, LowImportance, MAXIMUM_PROCESSORS, NULL, and TRUE. Referenced by KdExitDebugger(), KeSetTimerEx(), KiCalibrateTimeAdjustment(), and KiTimerListExpire().
|
|
Referenced by KiMemoryFault(), and MmAccessFault(). |
|
Definition at line 167 of file eventobj.c. References ASSERT, ASSERT_EVENT, DISPATCH_LEVEL, Event(), FALSE, Increment, KeGetCurrentThread, KiLockDispatcherDatabase, KiUnlockDispatcherDatabase(), KiWaitTest(), _KTHREAD::WaitIrql, and _KTHREAD::WaitNext. Referenced by ExUnlockHandleTableEntry(), MiFlushSectionInternal(), MiUnmapImageHeaderInHyperSpace(), MiWriteComplete(), MmLockPagableSectionByHandle(), MmUnlockPagableImageSection(), NtPulseEvent(), and xxxSwitchDesktop().
|
|
Definition at line 1004 of file ke/miscc.c. References KeActiveProcessors, and PAGED_CODE.
|
|
Definition at line 869 of file thredobj.c. References ASSERT_THREAD.
|
|
Definition at line 904 of file thredobj.c. References ASSERT, ASSERT_THREAD, _KPROCESS::BasePriority, DISPATCH_LEVEL, Increment, KiLockDispatcherDatabase, and KiUnlockDispatcherDatabase(). Referenced by NtQueryInformationThread().
|
|
Definition at line 122 of file ke/miscc.c. Referenced by ExGetNextWakeTime(), and KiCalibrateTimeAdjustment().
|
|
Definition at line 163 of file profobj.c. References HAL_PROFILE_SOURCE_INFORMATION, HalProfileSourceInformation, HalQuerySystemInformation, _HAL_PROFILE_SOURCE_INFORMATION::Interval, KiProfileAlignmentFixupInterval, KiProfileInterval, NT_SUCCESS, NTSTATUS(), _HAL_PROFILE_SOURCE_INFORMATION::Source, Status, and _HAL_PROFILE_SOURCE_INFORMATION::Supported. Referenced by NtQueryIntervalProfile().
|
|
Definition at line 968 of file thredobj.c.
|
|
|
Definition at line 211 of file ke/miscc.c. References KeMaximumIncrement. Referenced by CcInitializeCacheManager().
|
|
Definition at line 410 of file timerobj.c. References ASSERT_TIMER, KiLockDispatcherDatabase, and KiUnlockDispatcherDatabase(). Referenced by ExGetNextWakeTime().
|
|
Definition at line 1024 of file alpha/exceptn.c. References ASSERT, KeGetCurrentThread, KeRaiseUserExceptionDispatcher, and UserMode. Referenced by NtClose(), and NtSetEvent().
|
|
Definition at line 253 of file eventobj.c. References ASSERT_EVENT, and Event(). Referenced by IopCancelAlertedRequest(), IopConnectLinkTrackingPort(), IopSendMessageToTrackService(), NtQueryEvent(), and PspAddProcessToJob().
|
|
Definition at line 146 of file mutntobj.c. References ASSERT_MUTANT. Referenced by NtQueryMutant().
|
|
Definition at line 624 of file procobj.c. References ASSERT_PROCESS. Referenced by NtSetInformationJobObject(), NtSetInformationProcess(), and PsLockProcess().
|
|
Definition at line 92 of file queueobj.c. References ASSERT_QUEUE. Referenced by ExpDetectWorkerThreadDeadlock(), and NtQueryIoCompletion().
|
|
Definition at line 85 of file semphobj.c. References ASSERT_SEMAPHORE. Referenced by IoRaiseInformationalHardError(), LpcpDestroyPortQueue(), LpcRequestWaitReplyPort(), NtQuerySemaphore(), NtReplyWaitReplyPort(), NtRequestWaitReplyPort(), and NtSecureConnectPort().
|
|
Definition at line 993 of file thredobj.c. References ASSERT_THREAD. Referenced by NtQueryInformationThread().
|
|
|
|
Definition at line 1025 of file thredobj.c. References ASSERT, ASSERT_THREAD, DISPATCH_LEVEL, KiLockDispatcherDatabase, KiReadyThread(), and KiUnlockDispatcherDatabase(). Referenced by PspCreateThread().
|
|
Definition at line 1123 of file bugcheck.c. References Buffer, BufferEmpty, BufferInserted, FALSE, HIGH_LEVEL, KeBugCheckCallbackListHead, KeBugCheckCallbackLock, KeLowerIrql(), KeRaiseIrql(), PKBUGCHECK_CALLBACK_ROUTINE, and TRUE.
|
|
Definition at line 178 of file mutntobj.c. References APC_LEVEL, _KAPC_STATE::ApcListHead, _KTHREAD::ApcState, ASSERT, ASSERT_MUTANT, DISPATCH_LEVEL, ExRaiseStatus(), FALSE, Increment, KeGetCurrentThread, _KTHREAD::KernelApcDisable, _KAPC_STATE::KernelApcPending, KernelMode, KiLockDispatcherDatabase, KiRequestSoftwareInterrupt(), KiUnlockDispatcherDatabase(), KiWaitTest(), NULL, TRUE, _KTHREAD::WaitIrql, and _KTHREAD::WaitNext. Referenced by ExpDeleteMutant(), KeReleaseMutex(), MiLoadSystemImage(), MiLookupPsLoadedModule(), MmAddVerifierThunks(), MmGetVerifierInformation(), MmSetVerifierInformation(), MmUnloadSystemImage(), NtDuplicateObject(), NtQueryInformationProcess(), NtReleaseMutant(), NtSignalAndWaitForSingleObject(), ObFindHandleForObject(), ObInitProcess(), and ObKillProcess().
|
|
|
|
Definition at line 118 of file semphobj.c. References ASSERT, ASSERT_SEMAPHORE, DISPATCH_LEVEL, ExRaiseStatus(), FALSE, Increment, KeGetCurrentThread, KiLockDispatcherDatabase, KiUnlockDispatcherDatabase(), KiWaitTest(), _KTHREAD::WaitIrql, and _KTHREAD::WaitNext. Referenced by ExAllocatePool(), ExConvertExclusiveToSharedLite(), ExFreePool(), ExReleaseResourceForThreadLite(), ExReleaseResourceLite(), FsRtlDeregisterUncProvider(), FsRtlRegisterUncProvider(), IopAllocateBootResources(), IopAllocateResources(), IopHardwareProfileCancelRemovedDock(), IopHardwareProfileCancelTransition(), IopHardwareProfileCommitRemovedDock(), IopHardwareProfileCommitStartedDock(), IopLegacyResourceAllocation(), IopQueryConflictList(), IopReallocateResources(), IopRebalance(), IoRaiseInformationalHardError(), LpcpDestroyPortQueue(), LpcRequestPort(), LpcRequestWaitReplyPort(), MiChargeCommitmentCantExpand(), MiCheckForControlAreaDeletion(), MiContractPagingFiles(), MiIssuePageExtendRequest(), MiIssuePageExtendRequestNoWait(), NtAcceptConnectPort(), NtCompleteConnectPort(), NtReleaseSemaphore(), NtReplyPort(), NtReplyWaitReceivePort(), NtReplyWaitReceivePortEx(), NtReplyWaitReplyPort(), NtRequestPort(), NtRequestWaitReplyPort(), NtSecureConnectPort(), NtSignalAndWaitForSingleObject(), Reader(), ReaderTurnedWriter(), SmbTraceCompleteRdr(), SmbTraceCompleteSrv(), and Writer().
|
|
|
|
|
|
Definition at line 294 of file devquobj.c. References ASSERT, ASSERT_DEVICE_QUEUE, _KDEVICE_QUEUE_ENTRY::DeviceListEntry, DISPATCH_LEVEL, FALSE, _KDEVICE_QUEUE_ENTRY::Inserted, NULL, _KDEVICE_QUEUE_ENTRY::SortKey, and TRUE. Referenced by IoStartNextPacketByKey().
|
|
Definition at line 226 of file devquobj.c. References ASSERT, ASSERT_DEVICE_QUEUE, DISPATCH_LEVEL, FALSE, _KDEVICE_QUEUE_ENTRY::Inserted, NULL, and TRUE. Referenced by IoFreeController(), and IoStartNextPacket().
|
|
Definition at line 384 of file devquobj.c. References ASSERT, ASSERT_DEVICE_QUEUE, DISPATCH_LEVEL, FALSE, and TRUE.
|
|
Definition at line 238 of file queueobj.c. References _KTHREAD::Alertable, APC_LEVEL, _KTHREAD::ApcState, ASSERT, ASSERT_QUEUE, DISPATCH_LEVEL, _KTIMER::DueTime, ExWorkerQueue, FALSE, _KTIMER::Header, KeBugCheckEx(), KeGetCurrentThread, _KAPC_STATE::KernelApcPending, KernelMode, KiActivateWaiterQueue(), KiComputeWaitInterval(), KiInsertTreeTimer(), KiInsertWaitList, KiLockDispatcherDatabase, KiSwapThread(), KiUnlockDispatcherDatabase(), _KWAIT_BLOCK::NextWaitBlock, NTSTATUS(), NULL, _KWAIT_BLOCK::Object, _KTHREAD::Queue, _KTHREAD::QueueListEntry, _KTHREAD::State, _KWAIT_BLOCK::Thread, _KTHREAD::Timer, TRUE, _KAPC_STATE::UserApcPending, _KTHREAD::WaitBlock, _KTHREAD::WaitBlockList, Waiting, _KTHREAD::WaitIrql, _KWAIT_BLOCK::WaitKey, _KWAIT_BLOCK::WaitListEntry, _DISPATCHER_HEADER::WaitListHead, _KTHREAD::WaitMode, _KTHREAD::WaitNext, _KTHREAD::WaitReason, _KTHREAD::WaitStatus, _KTHREAD::WaitTime, _KWAIT_BLOCK::WaitType, and WrQueue. Referenced by ExpWorkerThread(), FsRtlWorkerThread(), and NtRemoveIoCompletion().
|
|
Definition at line 291 of file apcobj.c. References _KAPC_STATE::ApcListHead, _KTHREAD::ApcQueueLock, _KTHREAD::ApcStatePointer, ASSERT, ASSERT_APC, DISPATCH_LEVEL, FALSE, _KAPC_STATE::KernelApcPending, KernelMode, KiLockDispatcherDatabase, KiUnlockDispatcherDatabase(), PKAPC_STATE, and _KAPC_STATE::UserApcPending. Referenced by CmNotifyRunDown(), ExTimerRundown(), NtCancelTimer(), and NtSetTimer().
|
|
Definition at line 272 of file dpcobj.c. References ASSERT_DPC, Lock, and NULL. Referenced by ExTimerRundown(), KiCalibrateTimeAdjustment(), NtCancelTimer(), and NtSetTimer().
|
|
Definition at line 285 of file eventobj.c. References ASSERT, ASSERT_EVENT, DISPATCH_LEVEL, Event(), KiLockDispatcherDatabase, and KiUnlockDispatcherDatabase(). Referenced by IopSendMessageToTrackService(), NtReplyWaitReceivePort(), NtReplyWaitReceivePortEx(), NtResetEvent(), SmbTraceStart(), SmbTraceThreadEntry(), SmbTraceToClient(), and xHalIoSetPartitionInformation().
|
|
Definition at line 1079 of file thredobj.c. References ASSERT, ASSERT_THREAD, DISPATCH_LEVEL, KiLockDispatcherDatabase, KiUnlockDispatcherDatabase(), KiWaitTest(), and RESUME_INCREMENT. Referenced by NtResumeThread(), and PspCreateThread().
|
|
Definition at line 499 of file ke/debug.c. References FIRMWARE_REENTRY, and HalReturnToFirmware(). Referenced by IoWriteCrashDump().
|
|
Definition at line 1153 of file thredobj.c. References _KTHREAD::Affinity, ASSERT, DISPATCH_LEVEL, FALSE, KeGetCurrentPrcb, KeGetCurrentThread, KiLockDispatcherDatabase, KiSelectNextThread(), KiUnlockDispatcherDatabase(), NULL, Standby, _KTHREAD::State, _KTHREAD::SystemAffinityActive, and _KTHREAD::UserAffinity. Referenced by CmpConfigureProcessors(), CmpInitializeMachineDependentConfiguration(), Ke386CallBios(), KeConnectInterrupt(), KeDisconnectInterrupt(), KeSetSystemTime(), KeSetup80387OrEmulate(), and KiInitMachineDependent().
|
|
Definition at line 570 of file queueobj.c. References ASSERT, ASSERT_QUEUE, DISPATCH_LEVEL, KiLockDispatcherDatabase, KiUnlockDispatcherDatabase(), NULL, and _KTHREAD::Queue. Referenced by IopDeleteIoCompletion().
|
|
|
|
Definition at line 542 of file ke/i386/misc.c.
|
|
Definition at line 1302 of file thredobj.c. References _KPROCESS::Affinity, ASSERT, ASSERT_THREAD, ClearMember, DISPATCH_LEVEL, FALSE, INVALID_AFFINITY_SET, KeBugCheck(), KiDispatcherReadyListHead, KiLockDispatcherDatabase, KiProcessorBlock, KiReadySummary, KiReadyThread(), KiRequestDispatchInterrupt, KiSelectNextThread(), KiUnlockDispatcherDatabase(), NULL, Ready, Running, Standby, and _KTHREAD::State. Referenced by NtSetInformationProcess(), NtSetInformationThread(), and PspApplyJobLimitsToProcess().
|
|
Definition at line 224 of file ia64/thredini.c.
|
|
Definition at line 269 of file alpha/thredini.c. References ASSERT_THREAD, KiLockDispatcherDatabase, and KiUnlockDispatcherDatabase(). Referenced by NtSetInformationThread().
|
|
Definition at line 1532 of file thredobj.c. References abs, ASSERT, ASSERT_THREAD, _KPROCESS::BasePriority, DISPATCH_LEVEL, FALSE, Increment, KiLockDispatcherDatabase, KiSetPriorityThread(), KiUnlockDispatcherDatabase(), and _KPROCESS::ThreadQuantum. Referenced by ExpCreateWorkerThread(), ExpWorkerThreadBalanceManager(), and NtSetInformationThread().
|
|
Definition at line 1674 of file thredobj.c. References ASSERT, ASSERT_THREAD, DISPATCH_LEVEL, KiLockDispatcherDatabase, and KiUnlockDispatcherDatabase(). Referenced by NtSetInformationProcess(), and NtSetInformationThread().
|
|
Definition at line 907 of file procobj.c. References ASSERT_PROCESS. Referenced by PspApplyJobLimitsToProcess().
|
|
Definition at line 239 of file ke/miscc.c. References KiDmaIoCoherency.
|
|
|
Definition at line 458 of file eventobj.c. References _KTHREAD::ApcState, ASSERT, DISPATCH_LEVEL, Event(), EVENT_INCREMENT, FALSE, Increment, KiLockDispatcherDatabase, KiUnlockDispatcherDatabase(), KiUnwaitThread(), MmProductType, _KAPC_STATE::Process, _KTHREAD::Quantum, and _KPROCESS::ThreadQuantum. Referenced by ExReleaseResourceForThreadLite(), and ExReleaseResourceLite().
|
|
Definition at line 1735 of file thredobj.c. References ASSERT, KeNumberProcessors, KiLockDispatcherDatabase, KiUnlockDispatcherDatabase(), MAXIMUM_PROCESSORS, and _KPROCESS::ThreadSeed. Referenced by NtSetInformationThread().
|
|
Definition at line 367 of file dpcobj.c. References KDPC_IMPORTANCE.
|
|
Definition at line 223 of file profobj.c. References HAL_PROFILE_SOURCE_INTERVAL, HalProfileSourceInterval, HalSetProfileInterval(), HalSetSystemInformation, _HAL_PROFILE_SOURCE_INTERVAL::Interval, KiIpiGenericCall(), KiProfileAlignmentFixupInterval, KiProfileInterval, and _HAL_PROFILE_SOURCE_INTERVAL::Source. Referenced by NtSetIntervalProfile().
|
|
Definition at line 1799 of file thredobj.c. References _KTHREAD::EnableStackSwap, and KeGetCurrentThread. Referenced by ExpWorkerThread(), xxxDestroyThreadInfo(), and xxxInterSendMsgEx().
|
|
Definition at line 738 of file procobj.c. References ASSERT, ASSERT_PROCESS, _KTHREAD::BasePriority, _KTHREAD::DecrementCount, DISPATCH_LEVEL, KiLockDispatcherDatabase, KiSetPriorityThread(), KiUnlockDispatcherDatabase(), _KTHREAD::PriorityDecrement, _KTHREAD::Quantum, and _KTHREAD::Saturation. Referenced by NtSetInformationProcess(), and PsSetProcessPriorityByClass().
|
|
Definition at line 1838 of file thredobj.c. References ASSERT, ASSERT_THREAD, DISPATCH_LEVEL, FALSE, KiLockDispatcherDatabase, KiSetPriorityThread(), KiUnlockDispatcherDatabase(), and _KPROCESS::ThreadQuantum. Referenced by FsRtlWorkerThread(), KeBalanceSetManager(), KeBoostCurrentThread(), KeSwapProcessOrStack(), KiInitializeKernel(), MiDereferenceSegmentThread(), MiMappedPageWriter(), MiModifiedPageWriter(), MmZeroPageThread(), NtSetInformationThread(), PspExitThread(), and zzzSetWindowsHookEx().
|
|
Definition at line 656 of file procobj.c. References ASSERT, ASSERT_PROCESS, DISPATCH_LEVEL, Increment, KeGetCurrentThread, KiLockDispatcherDatabase, KiUnlockDispatcherDatabase(), KiWaitTest(), _KTHREAD::WaitIrql, and _KTHREAD::WaitNext. Referenced by PspExitProcess(), and PspExitThread().
|
|
Definition at line 909 of file ke/miscc.c. References KiSwapContextNotifyRoutine, and PAGED_CODE.
|
|
Definition at line 1467 of file thredobj.c. References _KTHREAD::Affinity, ASSERT, DISPATCH_LEVEL, KeActiveProcessors, KeGetCurrentPrcb, KeGetCurrentThread, KiLockDispatcherDatabase, KiSelectNextThread(), KiUnlockDispatcherDatabase(), NULL, Standby, _KTHREAD::State, _KTHREAD::SystemAffinityActive, and TRUE. Referenced by CmpConfigureProcessors(), CmpInitializeMachineDependentConfiguration(), Ke386CallBios(), KeConnectInterrupt(), KeDisconnectInterrupt(), KeSetSystemTime(), KeSetup80387OrEmulate(), and KiInitMachineDependent().
|
|
Definition at line 335 of file ke/miscc.c. References _DISPATCHER_HEADER::Absolute, ASSERT, DISPATCH_LEVEL, _KTIMER::DueTime, FALSE, HalSetRealTimeClock(), _KTIMER::Header, HIGH_LEVEL, Index, _DISPATCHER_HEADER::Inserted, KeBootTime, KeBootTimeBias, KeLowerIrql(), KeRaiseIrql(), KeRevertToUserAffinityThread(), KeSetSystemAffinityThread(), KiAdjustInterruptTime(), KiLockDispatcherDatabase, KiReinsertTreeTimer(), KiRemoveTreeTimer, KiTimerListExpire(), KiTimerTableListHead, KiUnlockDispatcherDatabase(), PoNotifySystemTimeSet(), RtlTimeToTimeFields(), TimeFields, TIMER_TABLE_SIZE, _KTIMER::TimerListEntry, and TRUE.
|
|
Definition at line 401 of file dpcobj.c. References MAXIMUM_PROCESSORS.
|
|
Definition at line 940 of file ke/miscc.c. References KiThreadSelectNotifyRoutine, and PAGED_CODE.
|
|
Definition at line 779 of file ke/miscc.c. References KeMaximumIncrement, KeMinimumIncrement, KeTimeAdjustment, KeTimeIncrement, KiTickOffset, and max.
|
|
Definition at line 243 of file timerobj.c. References KeSetTimerEx(). Referenced by CcCanIWrite(), CcScheduleLazyWriteScan(), CmpLazyFlush(), ExpWorkerThreadBalanceManager(), InternalSetTimer(), IopErrorLogQueueRequest(), KdpTimeSlipWork(), KeBalanceSetManager(), TimersProc(), and VdmpDelayInterrupt().
|
|
Definition at line 285 of file timerobj.c. References ASSERT, ASSERT_TIMER, DISPATCH_LEVEL, _KTIMER::Dpc, FALSE, _KTIMER::Header, KeInsertQueueDpc(), KiInsertTreeTimer(), KiLockDispatcherDatabase, KiRemoveTreeTimer, KiUnlockDispatcherDatabase(), KiWaitTest(), NULL, _KTIMER::Period, TIMER_EXPIRE_INCREMENT, and _DISPATCHER_HEADER::WaitListHead. Referenced by IoInitSystem(), IovpInternalDeferredCompletion(), KeSetTimer(), MiInitializeSpecialPoolCriteria(), MiInsertPageInList(), MiModifiedPageWriterWorker(), and NtSetTimer().
|
|
Definition at line 972 of file ke/miscc.c. References KiTimeUpdateNotifyRoutine, and PAGED_CODE.
|
|
Definition at line 324 of file procobj.c. References _KTHREAD::ApcState, _KTHREAD::ApcStateIndex, ASSERT, ASSERT_PROCESS, DISPATCH_LEVEL, FALSE, KeBugCheckEx(), KeGetCurrentThread, KiAttachProcess(), KiLockDispatcherDatabase, KiUnlockDispatcherDatabase(), NULL, _KAPC_STATE::Process, and _KTHREAD::SavedApcState. Referenced by NtClose(), NtSetInformationObject(), NtWaitForMultipleObjects(), ObpCreateHandle(), ObpCreateUnnamedHandle(), and PspProcessDelete().
|
|
Definition at line 78 of file alpha/allproc.c. References _MEMORY_ALLOCATION_DESCRIPTOR::BasePage, BLOCK1_SIZE, BLOCK2_SIZE, _BOOT_STATUS::BootFinished, _RESTART_BLOCK::BootStatus, ExAllocatePool, ExFreePool(), FALSE, HalStartNextProcessor(), KeLoaderBlock, KeRegisteredProcessors, _LOADER_PARAMETER_BLOCK::KernelStack, KiAdjustInterruptTime(), KiBarrierWait, KiFreePcrPagesDescriptor, KiStartProcessor(), KSEG0_BASE, _MEMORY_ALLOCATION_DESCRIPTOR::ListEntry, LoaderOsloaderHeap, MAXIMUM_PROCESSORS, _LOADER_PARAMETER_BLOCK::MemoryDescriptorListHead, _MEMORY_ALLOCATION_DESCRIPTOR::MemoryType, NonPagedPool, NULL, PAGE_SHIFT, PAGE_SIZE, _MEMORY_ALLOCATION_DESCRIPTOR::PageCount, PMEMORY_ALLOCATION_DESCRIPTOR, _LOADER_PARAMETER_BLOCK::Prcb, ROUND_UP, _LOADER_PARAMETER_BLOCK::Thread, and _LOADER_PARAMETER_BLOCK::u.
|
|
Definition at line 289 of file profobj.c. References _KACTIVE_PROFILE_SOURCE::Affinity, ASSERT, ASSERT_PROFILE, Buffer, DISPATCH_LEVEL, ExAllocatePoolWithTag, ExFreePool(), FALSE, HalStartProfileInterrupt(), KeGetCurrentPrcb, KeLowerIrql(), KeNumberProcessors, KeRaiseIrql(), KiEnableAlignmentExceptions, KiIpiSendPacket(), KiIpiStallOnPacketTargets(), KiProfileAlignmentFixup, KiProfileIrql, KiProfileListHead, KiProfileLock, KiProfileSourceListHead, KiStartProfileInterrupt(), L, _KACTIVE_PROFILE_SOURCE::ListEntry, NonPagedPool, NULL, PKACTIVE_PROFILE_SOURCE, _KACTIVE_PROFILE_SOURCE::ProcessorCount, _KPROCESS::ProfileListHead, _KACTIVE_PROFILE_SOURCE::Source, and TRUE. Referenced by NtStartProfile().
|
|
Definition at line 520 of file profobj.c. References _KACTIVE_PROFILE_SOURCE::Affinity, ASSERT, ASSERT_PROFILE, DISPATCH_LEVEL, ExFreePool(), FALSE, HalStopProfileInterrupt(), KeGetCurrentPrcb, KeLowerIrql(), KeRaiseIrql(), KiDisableAlignmentExceptions, KiIpiSendPacket(), KiIpiStallOnPacketTargets(), KiProfileAlignmentFixup, KiProfileIrql, KiProfileLock, KiProfileSourceListHead, KiStopProfileInterrupt(), L, _KACTIVE_PROFILE_SOURCE::ListEntry, NULL, PKACTIVE_PROFILE_SOURCE, _KACTIVE_PROFILE_SOURCE::ProcessorCount, _KACTIVE_PROFILE_SOURCE::Source, and TRUE. Referenced by ExpProfileDelete(), and NtStopProfile().
|
|
Definition at line 1912 of file thredobj.c. References ASSERT, ASSERT_THREAD, DISPATCH_LEVEL, ExRaiseStatus(), FALSE, KiInsertQueueApc(), KiLockDispatcherDatabase, KiUnlockDispatcherDatabase(), and RESUME_INCREMENT. Referenced by NtSuspendThread(), and PspCreateThread().
|
|
Definition at line 322 of file balmgr.c. References Executive, FALSE, KeGetCurrentThread, KernelMode, KeSetPriorityThread(), KeWaitForSingleObject(), KiInSwapKernelStacks(), KiInSwapProcesses(), KiLockDispatcherDatabase, KiOutSwapKernelStacks(), KiOutSwapProcesses(), KiProcessInSwapListHead, KiProcessOutSwapListHead, KiStackInSwapListHead, KiStackOutSwapRequest, KiSwapEvent, KiUnlockDispatcherDatabase(), NTSTATUS(), NULL, Status, and TRUE. Referenced by MmInitSystem().
|
|
Definition at line 334 of file ke/debug.c. References ContinueError, ContinueNextProcessor, ContinueProcessorReselected, FREEZE_ACTIVE, FREEZE_OWNER, FrozenState, KeGetCurrentPrcb, KeNumberProcessors, KiProcessorBlock, and TARGET_FROZEN. Referenced by KdpSendWaitContinue().
|
|
Referenced by PsConvertToGuiThread(). |
|
Referenced by VerifierSynchronizeExecution(). |
|
Definition at line 1996 of file thredobj.c. References ASSERT, BALANCE_INCREMENT, DISPATCH_LEVEL, ExWorkerQueue, FALSE, _KEVENT::Header, HyperCriticalWorkQueue, Increment, KeGetCurrentThread, KiActivateWaiterQueue(), KiInsertQueue(), KiLockDispatcherDatabase, KiProcessOutSwapListHead, KiRundownThread, KiSwapEvent, KiSwapThread(), KiWaitTest(), _WORK_QUEUE_ITEM::List, NULL, ProcessInTransition, PsReaperActive, PsReaperListHead, PsReaperWorkItem, _DISPATCHER_HEADER::SignalState, _KPROCESS::StackCount, _KPROCESS::State, _KPROCESS::SwapListEntry, Terminated, _ETHREAD::ThreadListEntry, _KPROCESS::ThreadListHead, TRUE, and _DISPATCHER_HEADER::WaitListHead. Referenced by PspExitThread().
|
|
Definition at line 2121 of file thredobj.c. References _KTHREAD::Alerted, _KAPC_STATE::ApcListHead, _KTHREAD::ApcQueueLock, _KTHREAD::ApcState, ASSERT, DISPATCH_LEVEL, FALSE, KeGetCurrentThread, KiLockDispatcherDatabase, KiUnlockDispatcherDatabase(), TRUE, _KAPC_STATE::UserApcPending, and UserMode. Referenced by KiDeliverApc(), and NtTestAlert().
|
|
Definition at line 2190 of file thredobj.c. References ASSERT, DISPATCH_LEVEL, _KTHREAD::FreezeCount, _KSEMAPHORE::Header, KeGetCurrentThread, KeLeaveCriticalRegion, KiLockDispatcherDatabase, KiUnlockDispatcherDatabase(), KiWaitTest(), RESUME_INCREMENT, _DISPATCHER_HEADER::SignalState, _KTHREAD::SuspendCount, _KTHREAD::SuspendSemaphore, and _KPROCESS::ThreadListHead. Referenced by DbgkpResumeProcess().
|
|
Definition at line 391 of file ke/debug.c. References ClearMember, FREEZE_BACKUP, FrozenState, KeActiveProcessors, KeFindFirstSetRightMember, KeFlushCurrentTb(), KeGetCurrentPrcb, KeLowerIrql(), KiFreezeExecutionLock, KiFreezeFlag, KiFreezeLockBackup, KiOldIrql, KiProcessorBlock, KiRestoreInterrupts(), RUNNING, TARGET_FROZEN, and TARGET_THAW. Referenced by KdExitDebugger().
|
|
Referenced by MmTrimAllSystemPagableMemory(). |
|
Definition at line 512 of file procobj.c. References APC_LEVEL, _KAPC_STATE::ApcListHead, _KTHREAD::ApcState, _KTHREAD::ApcStateIndex, _KTHREAD::ApcStatePointer, ASSERT, BALANCE_INCREMENT, DISPATCH_LEVEL, FALSE, _KEVENT::Header, KeBugCheck(), KeGetCurrentThread, _KAPC_STATE::KernelApcInProgress, _KAPC_STATE::KernelApcPending, KernelMode, KiLockDispatcherDatabase, KiMoveApcState(), KiProcessOutSwapListHead, KiRequestSoftwareInterrupt(), KiSwapEvent, KiSwapProcess(), KiUnlockDispatcherDatabase(), KiWaitTest(), NULL, _KAPC_STATE::Process, ProcessInTransition, _KTHREAD::SavedApcState, _DISPATCHER_HEADER::SignalState, _KPROCESS::StackCount, _KPROCESS::State, _KPROCESS::SwapListEntry, _KPROCESS::ThreadListHead, TRUE, UserMode, and _DISPATCHER_HEADER::WaitListHead. Referenced by NtClose(), NtSetInformationObject(), NtWaitForMultipleObjects(), ObpCreateHandle(), ObpCreateUnnamedHandle(), and PspProcessDelete().
|
|
|
|
Definition at line 395 of file wait.c. References _KTHREAD::Alertable, APC_LEVEL, _KTHREAD::ApcState, ASSERT, Count, DISPATCH_LEVEL, _KTIMER::DueTime, ExRaiseStatus(), FALSE, _KMUTANT::Header, _KTIMER::Header, Index, KeBugCheck(), KeGetCurrentThread, _KAPC_STATE::KernelApcPending, KiActivateWaiterQueue(), KiAdjustQuantumThread(), KiComputeWaitInterval(), KiInsertTreeTimer(), KiInsertWaitList, KiLockDispatcherDatabase, KiSwapThread(), KiUnlockDispatcherDatabase(), KiWaitSatisfyAll(), KiWaitSatisfyMutant, KiWaitSatisfyOther, KWAIT_REASON, MutantObject, _KWAIT_BLOCK::NextWaitBlock, NTSTATUS(), NULL, _KWAIT_BLOCK::Object, _KMUTANT::OwnerThread, _KTHREAD::Queue, QueueObject, _DISPATCHER_HEADER::SignalState, _KTHREAD::State, TestForAlertPending, _KWAIT_BLOCK::Thread, THREAD_WAIT_OBJECTS, _KTHREAD::Timer, TIMER_WAIT_BLOCK, TRUE, _DISPATCHER_HEADER::Type, USHORT, _KTHREAD::WaitBlock, _KTHREAD::WaitBlockList, Waiting, _KTHREAD::WaitIrql, _KWAIT_BLOCK::WaitKey, _KWAIT_BLOCK::WaitListEntry, _DISPATCHER_HEADER::WaitListHead, _KTHREAD::WaitMode, _KTHREAD::WaitNext, _KTHREAD::WaitReason, _KTHREAD::WaitStatus, _KTHREAD::WaitTime, and _KWAIT_BLOCK::WaitType. Referenced by CmpFileWrite(), ExpWorkerThreadBalanceManager(), InitiateWin32kCleanup(), KeBalanceSetManager(), MemPrintWriteThread(), MiDereferenceSegmentThread(), MiModifiedPageWriterWorker(), MmZeroPageThread(), NtWaitForMultipleObjects(), RawInputThread(), SmbTraceThreadEntry(), xxxMsgWaitForMultipleObjects(), xxxPollAndWaitForSingleObject(), and xxxSleepTask().
|
|
|
Definition at line 576 of file thredsup.c. References ASSERT, ClearMember, FALSE, KiDispatcherReadyListHead, KiFindReadyThread(), KiProcessorBlock, KiReadySummary, KiReadyThread(), KiRequestDispatchInterrupt, NULL, Ready, Running, SetMember, Standby, and _KTHREAD::State. Referenced by ExpBoostOwnerThread(), KeDelayExecutionThread(), KeSetBasePriorityThread(), KeSetPriorityProcess(), KeSetPriorityThread(), KiAdjustQuantumThread(), and KiQuantumEnd().
|
|
Definition at line 1126 of file wait.c. References EVENT_INCREMENT, FALSE, KeSetEvent(), KeWaitForSingleObject(), KPROCESSOR_MODE, NULL, TRUE, and WrEventPair.
|
|
|
Definition at line 2767 of file ke.h. Referenced by IopCopyBootLogRegistryToFile(), KeSetSystemTime(), NtQuerySystemInformation(), and ViInjectResourceFailure(). |
|
Definition at line 2768 of file ke.h. Referenced by KeSetSystemTime(), and NtQuerySystemInformation(). |
|
Definition at line 2770 of file ke.h. Referenced by KeRegisterBugCheckCallback(), KiInitSystem(), and KiScanBugCheckCallbackList(). |
|
Definition at line 2771 of file ke.h. Referenced by KeDeregisterBugCheckCallback(), KeRegisterBugCheckCallback(), and KiInitSystem(). |
|
Definition at line 2780 of file ke.h. Referenced by KeI386VdmInitialize(), KeRestoreMtrr(), KeRestorePAT(), KeSetPhysicalCacheTypeRange(), KeSetup80387OrEmulate(), KiInitializeKernel(), KiInitializeMTRR(), KiInitializePAT(), KiInitMachineDependent(), KiLoadMTRR(), MiInitMachineDependent(), MmMapIoSpace(), and NtQuerySystemInformation(). |
|
Definition at line 2772 of file ke.h. Referenced by KeUserModeCallback(), and PsEstablishWin32Callouts(). |
|
Definition at line 2769 of file ke.h. Referenced by KiCalibrateTimeAdjustment(), and NtQuerySystemInformation(). |
|
|
|
Definition at line 2773 of file ke.h. Referenced by CmpCreateHwProfileFriendlyName(), KeDumpMachineState(), KeStartAllProcessors(), KiInitializeAbios(), KiInitializeKernel(), KiInitializeMachineType(), and KiPcToFileHeader(). |
|
|
Definition at line 2775 of file ke.h. Referenced by KeSetTimeIncrement(), and VdmpDelayInterrupt(). |
|
|
Definition at line 2777 of file ke.h. Referenced by IopInitializeDCB(), KiInitializeKernel(), and NtQuerySystemInformation(). |
|
Definition at line 2778 of file ke.h. Referenced by KdpPrintString(), KdpPromptString(), KdpReportLoadSymbolsStateChange(), KdpSetStateChange(), KiDisableAlignmentExceptions(), KiEnableAlignmentExceptions(), KiInitializeKernel(), MmDbgTranslatePhysicalAddress64(), and NtQuerySystemInformation(). |
|
Definition at line 2779 of file ke.h. Referenced by KiInitializeKernel(), and NtQuerySystemInformation(). |
|
Definition at line 2811 of file ke.h. Referenced by KeRaiseUserException(), and PspLookupKernelUserEntryPoints(). |
|
Definition at line 2788 of file ke.h. Referenced by KeStartAllProcessors(). |
|
|
|
Definition at line 2794 of file ke.h. Referenced by KeAddSystemServiceTable(), KeInitializeThread(), KiInitSystem(), NtW32Call(), and PsConvertToGuiThread(). |
|
Definition at line 2795 of file ke.h. Referenced by KeAddSystemServiceTable(), KiInitSystem(), NtQuerySystemInformation(), and PsConvertToGuiThread(). |
|
Definition at line 2784 of file ke.h. Referenced by NtQuerySystemInformation(). |
|
Definition at line 2797 of file ke.h. Referenced by IoCreateDriver(), KeUpdateSystemTime(), KiCalibrateTimeAdjustment(), and NtGetTickCount(). |
|
Definition at line 2812 of file ke.h. Referenced by KeSetTimeIncrement(), KeUpdateSystemTime(), NtQuerySystemInformation(), and NtSetSystemInformation(). |
|
Definition at line 2813 of file ke.h. Referenced by KeSetTimeIncrement(), KiCalibrateTimeAdjustment(), NtQuerySystemInformation(), and VdmpDelayInterrupt(). |
|
Definition at line 2814 of file ke.h. Referenced by NtQuerySystemInformation(), and NtSetSystemInformation(). |
|
Definition at line 2808 of file ke.h. Referenced by KiInitializeUserApc(), and PspLookupKernelUserEntryPoints(). |
|
Definition at line 2809 of file ke.h. Referenced by KdInitSystem(), KdpGetVersion(), KdUpdateDataBlock(), and PspLookupKernelUserEntryPoints(). |
|
Definition at line 2810 of file ke.h. Referenced by KiDispatchException(), and PspLookupKernelUserEntryPoints(). |
|
|
|
|
Definition at line 2783 of file ke.h. Referenced by KeBalanceSetManager(), KiOutSwapKernelStacks(), MiApplyDriverVerifier(), and MiVerifyingDriverUnloading(). |