Author: gvg Date: Wed Apr 26 01:37:06 2006 New Revision: 21739
URL: http://svn.reactos.ru/svn/reactos?rev=21739&view=rev Log: Create list of functions for audit
Added: branches/ntoskrnl-audit/reactos/ntoskrnl/function_list.txt (with props)
Added: branches/ntoskrnl-audit/reactos/ntoskrnl/function_list.txt URL: http://svn.reactos.ru/svn/reactos/branches/ntoskrnl-audit/reactos/ntoskrnl/f... ============================================================================== --- branches/ntoskrnl-audit/reactos/ntoskrnl/function_list.txt (added) +++ branches/ntoskrnl-audit/reactos/ntoskrnl/function_list.txt Wed Apr 26 01:37:06 2006 @@ -1,0 +1,1043 @@ +ntoskrnl/cc/fs.c + +CcGetDirtyPages +CcGetFileObjectFromBcb +CcGetLsnForFileObject +CcInitializeCacheMap +CcIsThereDirtyData +CcPurgeCacheSection +CcSetFileSizes +CcSetLogHandleForFile +CcUninitializeCacheMap + +ntoskrnl/cc/view.c + +CcTryToAcquireBrokenMutex + +ntoskrnl/cc/copy.c + +CcDeferWrite +CcFastCopyRead +CcFastCopyWrite +CcWaitForCurrentLazyWriterActivity + +ntoskrnl/cc/pin.c + +CcPinMappedData +CcPinRead +CcSetDirtyPinnedData + +ntoskrnl/cc/mdl.c + +CcMdlRead +CcMdlReadCompleteDev +CcMdlReadComplete +CcMdlWriteComplete +CcMdlWriteCompleteDev +CcMdlWriteAbort +CcPrepareMdlWrite + +ntoskrnl/cc/cacheman.c + +CcGetFlushedValidData +CcRemapBcb +CcScheduleReadAhead +CcSetAdditionalCacheAttributes +CcSetBcbOwnerPointer +CcSetDirtyPageThreshold +CcSetReadAheadGranularity + +ntoskrnl/cm/ntfunc.c + +NtNotifyChangeKey +NtSaveKeyEx + +ntoskrnl/dbgk/dbgkutil.c + +DbgkCreateThread + +ntoskrnl/dbgk/debug.c + +NtCreateDebugObject +NtWaitForDebugEvent +NtDebugContinue +NtDebugActiveProcess +NtRemoveProcessDebug +NtSetInformationDebugObject + +ntoskrnl/ex/lookas.c + +ExpInitLookasideLists +ExiAllocateFromPagedLookasideList +ExiFreeToPagedLookasideList +ExDeleteNPagedLookasideList +ExDeletePagedLookasideList +ExInitializeNPagedLookasideList +ExInitializePagedLookasideList + +ntoskrnl/ex/event.c + +ExpInitializeEventImplementation +NtCreateEvent +NtOpenEvent +NtPulseEvent +NtQueryEvent +NtResetEvent +NtSetEvent + +ntoskrnl/ex/work.c + +ExpWorkerThreadEntryPoint +ExpCreateWorkerThread +ExpDetectWorkerThreadDeadlock +ExpCheckDynamicThreadCount +ExpWorkerThreadBalanceManager +ExpInitializeWorkerThreads +ExQueueWorkItem + +ntoskrnl/ex/init.c + +ExpDisplayNotice +ExpLoadInitialProcess +ExInit2 + +ntoskrnl/ex/atom.c + +ExpGetGlobalAtomTable +NtAddAtom +NtDeleteAtom +NtFindAtom +NtQueryInformationAtom + +ntoskrnl/ex/mutant.c + +ExpInitializeMutantImplementation +NtCreateMutant +NtOpenMutant +NtQueryMutant +NtReleaseMutant + +ntoskrnl/ex/win32k.c + +ExpWinStaObjectOpen +ExpWin32kInit + +ntoskrnl/ex/dbgctrl.c + +NtSystemDebugControl + +ntoskrnl/ex/rundown.c + +ExfAcquireRundownProtection +ExfAcquireRundownProtectionEx +ExfInitializeRundownProtection +ExfReInitializeRundownProtection +ExfRundownCompleted +ExfReleaseRundownProtection +ExfReleaseRundownProtectionEx +ExfWaitForRundownProtectionRelease +ExfAcquireRundownProtectionCacheAware +ExfAcquireRundownProtectionCacheAwareEx +ExfReleaseRundownProtectionCacheAware +ExfReleaseRundownProtectionCacheAwareEx +ExfWaitForRundownProtectionReleaseCacheAware +ExfRundownCompletedCacheAware +ExfReInitializeRundownProtectionCacheAware +ExAllocateCacheAwareRundownProtection +ExFreeCacheAwareRundownProtection +ExInitializeRundownProtectionCacheAware +ExSizeOfRundownProtectionCacheAware + +ntoskrnl/ex/evtpair.c + +ExpInitializeEventPairImplementation +NtCreateEventPair +NtOpenEventPair + +ntoskrnl/ex/sem.c + +ExpInitializeSemaphoreImplementation +NtCreateSemaphore +NtOpenSemaphore +NtQuerySemaphore +NtReleaseSemaphore + +ntoskrnl/ex/sysinfo.c + +ExEnumHandleTable +ExGetCurrentProcessorCpuUsage +ExVerifySuite +QSI_DEF +QSI_DEF +SSI_DEF + +ntoskrnl/ex/resource.c + +ExpVerifyResource +ExpCheckForApcsDisabled +ExpResourceInitialization +ExpAllocateExclusiveWaiterEvent +ExpAllocateSharedWaiterSemaphore +ExpExpandResourceOwnerTable +ExpFindFreeEntry +ExpFindEntryForThread +ExpBoostOwnerThread +ExpWaitForResource +ExAcquireResourceExclusiveLite +ExAcquireResourceSharedLite +ExAcquireSharedStarveExclusive +ExAcquireSharedWaitForExclusive +ExConvertExclusiveToSharedLite +ExDeleteResourceLite +ExDisableResourceBoostLite +ExGetExclusiveWaiterCount +ExGetSharedWaiterCount +ExInitializeResourceLite +ExIsResourceAcquiredExclusiveLite +ExIsResourceAcquiredSharedLite +ExReinitializeResourceLite +ExReleaseResourceLite +ExReleaseResourceForThreadLite +ExSetResourceOwnerPointer +ExTryToAcquireResourceExclusiveLite +ExEnterCriticalRegionAndAcquireResourceExclusive +ExReleaseResourceAndLeaveCriticalRegion + +ntoskrnl/ex/time.c + +ExpInitTimeZoneInfo +ExpSetTimeZoneInformation +NtSetSystemTime +NtQuerySystemTime +ExSetTimerResolution + +ntoskrnl/ex/profile.c + +ExpDeleteProfile +ExpInitializeProfileImplementation +NtCreateProfile +NtQueryPerformanceCounter +NtQueryIntervalProfile + +ntoskrnl/ex/pushlock.c + +ExpInitializePushLocks +ExfWakePushLock +ExpOptimizePushLockList +ExTimedWaitForUnblockPushLock +ExBlockPushLock +ExfAcquirePushLockExclusive +ExfAcquirePushLockShared +ExfReleasePushLock +ExfReleasePushLockShared +ExfReleasePushLockExclusive +ExfTryToWakePushLock +ExfUnblockPushLock + +ntoskrnl/ex/error.c + +ExpRaiseHardError +ExSystemExceptionFilter +ExRaiseHardError +NtRaiseHardError +_purecall + +ntoskrnl/ex/timer.c + +ExTimerRundown +ExpDeleteTimer +ExpTimerDpcRoutine +ExpTimerApcKernelRoutine +ExpInitializeTimerImplementation +NtCancelTimer +NtCreateTimer +NtOpenTimer +NtQueryTimer +NtSetTimer + +ntoskrnl/ex/fmutex.c + +ExEnterCriticalRegionAndAcquireFastMutexUnsafe +ExReleaseFastMutexUnsafeAndLeaveCriticalRegion +ExAcquireFastMutex +ExReleaseFastMutex +ExAcquireFastMutexUnsafe +ExReleaseFastMutexUnsafe +ExTryToAcquireFastMutex + +ntoskrnl/ex/zone.c + +ExExtendZone +ExInterlockedExtendZone +ExInitializeZone + +ntoskrnl/ex/uuid.c + +ExUuidCreate + +ntoskrnl/fs/util.c + +RtlpInitializeResources +FsRtlIsTotalDeviceFailure +FsRtlAllocateResource +FsRtlBalanceReads + +ntoskrnl/fs/filelock.c + +FsRtlAcquireFileExclusive +FsRtlReleaseFile + +ntoskrnl/fs/fastio.c + +FsRtlIncrementCcFastReadResourceMiss +FsRtlIncrementCcFastReadNotPossible +FsRtlIncrementCcFastReadWait +FsRtlIncrementCcFastReadNoWait +FsRtlCopyRead +FsRtlCopyWrite +FsRtlGetFileSize +FsRtlMdlRead +FsRtlMdlReadComplete +FsRtlMdlReadCompleteDev +FsRtlMdlReadDev +FsRtlMdlWriteComplete +FsRtlMdlWriteCompleteDev +FsRtlPrepareMdlWrite +FsRtlPrepareMdlWriteDev + +ntoskrnl/fs/name.c + +FsRtlAreNamesEqual +FsRtlDissectDbcs +FsRtlDoesDbcsContainWildCards +FsRtlDoesNameContainWildCards +FsRtlIsDbcsInExpression +FsRtlIsFatDbcsLegal +FsRtlIsHpfsDbcsLegal + +ntoskrnl/fs/mcb.c + +FsRtlGetNextMcbEntry +FsRtlLookupLastLargeMcbEntryAndIndex +FsRtlLookupPerStreamContextInternal +FsRtlLookupPerFileObjectContext +FsRtlLookupLastMcbEntry +FsRtlLookupMcbEntry +FsRtlRemoveMcbEntry +FsRtlResetLargeMcb + +ntoskrnl/fs/notify.c + +FsRtlNotifyFilterChangeDirectory +FsRtlNotifyFilterReportChange +FsRtlRegisterFileSystemFilterCallbacks + +ntoskrnl/fs/context.c + +FsRtlInsertPerStreamContext +FsRtlRemovePerStreamContext +FsRtlInsertPerFileObjectContext +FsRtlRemovePerFileObjectContext +FsRtlTeardownPerStreamContexts + +ntoskrnl/inbv/inbv.c + +InbvDisplayString +NtDisplayString + +ntoskrnl/kd/kdinit.c + +KdpGetWrapperDebugMode +KdpGetDebugMode +KdpCallInitRoutine +KdInitSystem + +ntoskrnl/kd/kdio.c + +KdpPrintToLogInternal +KdpPrintToLog +KdpInitDebugLog +KdpSerialDebugPrint +KdpSerialInit +KdpScreenPrint +KdpScreenInit +KdpDetectConflicts +KdpPrintString + +ntoskrnl/kd/kdmain.c + +KdpServiceDispatcher +KdpEnterDebuggerException +KdDisableDebugger +KdEnableDebugger +KdPollBreakIn +KeEnterKernelDebugger +KdPowerTransition +NtQueryDebugFilterState +NtSetDebugFilterState + +ntoskrnl/kd/wrappers/bochs.c + +KdpBochsDebugPrint +KdpBochsInit + +ntoskrnl/kd/wrappers/gdbstub.c + +GdbPutChar +GdbGetChar +GspGetPacket +GspPutPacket +GspPutPacketNoWait +GspMem2Hex +while +GspComputeSignal +GspHex2Long +GspLong2Hex +GspGetEspFromTrapFrame +GspSetRegistersInTrapFrame +GspSetSingleRegisterInTrapFrame +GspFindThread +GspQueryThreadStatus +KdpGdbEnterDebuggerException +GspBreakIn +KdpGdbDebugPrint +KdpGdbStubInit + +ntoskrnl/kdbg/kdb.c + +KdbpGetCommandLineSettings + +ntoskrnl/kdbg/kdb_symbols.c + +KdbSymLoadDriverSymbols +KdbSymUnloadDriverSymbols + +ntoskrnl/ke/dpc.c + +KeFlushQueuedDpcs + +ntoskrnl/ke/clock.c + +KiInitializeSystemClock +KiSetSystemTime +KeQueryTimeIncrement +KeQueryTickCount +KeQuerySystemTime +KeQueryInterruptTime +KeSetTimeIncrement +KeSetTimeUpdateNotifyRoutine +KeUpdateRunTime +KeUpdateSystemTime +NtGetTickCount +NtQueryTimerResolution +NtSetTimerResolution + +ntoskrnl/ke/exception.c + +KiContinuePreviousModeUser +KiContinue +KiRaiseException + +ntoskrnl/ke/usercall.c + +KeUserModeCallback + +ntoskrnl/ke/mutex.c + +KeReleaseMutant + +ntoskrnl/ke/spinlock.c + +KeSynchronizeExecution +KeAcquireInterruptSpinLock +KefAcquireSpinLockAtDpcLevel +KeAcquireSpinLockAtDpcLevel +KefReleaseSpinLockFromDpcLevel +KiAcquireSpinLock +KeReleaseInterruptSpinLock +KiReleaseSpinLock +KeAcquireQueuedSpinLockAtDpcLevel +KeReleaseQueuedSpinLockFromDpcLevel +KeAcquireInStackQueuedSpinLockAtDpcLevel +KeReleaseInStackQueuedSpinLockFromDpcLevel + +ntoskrnl/ke/wait.c + +KiWaitSatisfyAll +KeDelayExecutionThread +KeWaitForSingleObject +KeWaitForMultipleObjects +KiWaitTest +KiAbortWaitThread +KiAcquireFastMutex +KiExitDispatcher + +ntoskrnl/ke/gate.c + +KeInitializeGate +KeWaitForGate +KeSignalGateBoostPriority + +ntoskrnl/ke/kthread.c + +KiRequestReschedule +KiInsertIntoThreadList +KiRemoveFromThreadList +KiScanThreadList +KiDispatchThreadNoLock +KiSwapThread +KiDispatchThread +KiUnblockThread +KiAdjustQuantumThread +KiSuspendThreadKernelRoutine +KiSuspendThreadNormalRoutine +KeGetCurrentThread +KeSetPreviousMode +KeGetPreviousMode +KeDisableThreadApcQueueing +KeRundownThread +KeResumeThread +KeFreezeAllThreads +KeSuspendThread +KeForceResumeThread +KeCapturePersistentThreadState +KeInitializeThread +KeQueryPriorityThread +KeQueryBasePriorityThread +KiSetPriorityThread +KeSetBasePriorityThread +KeSetPriorityThread +KeSetAffinityThread +KeTerminateThread + +ntoskrnl/ke/device.c + +KeFindConfigurationEntry +KeFindConfigurationNextEntry +KeFlushEntireTb +KeSetDmaIoCoherency +KeQueryActiveProcessors +KeSaveStateForHibernate + +ntoskrnl/ke/process.c + +KeGetCurrentProcess +KiAttachProcess +KeInitializeProcess +KeSetProcess +KiSwapProcess +KeAttachProcess +KeDetachProcess +KeIsAttachedProcess +KeStackAttachProcess +KeUnstackDetachProcess +KeAddSystemServiceTable +KeRemoveSystemServiceTable + +ntoskrnl/ke/queue.c + +KeInitializeQueue +KeInsertHeadQueue +KeInsertQueue +KeReadStateQueue +KeRemoveQueue +KeRundownQueue +KiWakeQueue +KiInsertQueue + +ntoskrnl/ke/profile.c + +KeInitializeProfile +KeProfileInterrupt +KeSetProfileIrql + +ntoskrnl/ke/i386/exp.c + +KiEspFromTrapFrame +KiEspToTrapFrame +KiSsFromTrapFrame +KiSsToTrapFrame +KeContextToTrapFrame +KeTrapFrameToContext +KeInitExceptions +KiDispatchException +KeRaiseUserException + +ntoskrnl/ke/i386/irq.c + +KeIRQTrapFrameToTrapFrame +KeTrapFrameToIRQTrapFrame +KeDisconnectInterrupt +KeInitializeInterrupt + +ntoskrnl/ke/i386/thread.c + +Ke386InitThreadWithContext + +ntoskrnl/ke/i386/tss.c + +Ki386BootInitializeTSS + +ntoskrnl/ke/i386/vdm.c + +NtEarlyInitVdm + +ntoskrnl/ke/i386/kernel.c + +KeApplicationProcessorInitDispatcher +KeCreateApplicationProcessorIdleThread +Ki386SetProcessorFeatures + +ntoskrnl/ke/i386/gdt.c + +KeI386FlatToGdtSelector +KeI386ReleaseGdtSelectors +KeI386AllocateGdtSelectors + +ntoskrnl/ke/timer.c + +KeCancelTimer +KeInitializeTimer +KeInitializeTimerEx +KeReadStateTimer +KeSetTimer +KeSetTimerEx +KiExpireTimers +KiHandleExpiredTimer +KiInsertTimer + +ntoskrnl/ke/kqueue.c + +KeRemoveByKeyDeviceQueueIfBusy + +ntoskrnl/ke/gmutex.c + +KeEnterGuardedRegion +KeLeaveGuardedRegion +KeInitializeGuardedMutex +KiAcquireGuardedMutexContented +KeAcquireGuardedMutexUnsafe +KeReleaseGuardedMutexUnsafe +KeReleaseGuardedMutex +KeTryToAcquireGuardedMutex + +ntoskrnl/ke/apc.c + +KiCheckForKernelApcDelivery +KeLeaveCriticalRegion +KiRequestApcInterrupt +KiInsertQueueApc +KeInsertQueueApc +KeFlushQueueApc +KeRemoveQueueApc +KiDeliverApc +KiFreeApcRoutine +KiInitializeUserApc +KeAreApcsDisabled + +ntoskrnl/lpc/port.c + +LpcpInitSystem + +ntoskrnl/lpc/reply.c + +NtReplyWaitReceivePort +LpcRequestWaitReplyPort + +ntoskrnl/mm/pagefile.c + +MmIsFileAPagingFile + +ntoskrnl/mm/virtual.c + +MmGetVirtualForPhysical + +ntoskrnl/mm/pe.c + +Intsafe_CanAddULongPtr +Intsafe_CanAddLong64 +Intsafe_CanAddULong32 +Intsafe_AddULong32 +Intsafe_CanMulULong32 +Intsafe_CanOffsetPointer +IsPowerOf2 +ModPow2 +IsAligned + +ntoskrnl/mm/elf.inc.h + +Intsafe_CanAddULongPtr +Intsafe_CanAddULong32 +Intsafe_AddULong32 +Intsafe_CanAddULong64 +Intsafe_AddULong64 +Intsafe_CanMulULong32 +Intsafe_MulULong32 +Intsafe_CanOffsetPointer +ElfFmtpReadULong64 +ElfFmtpReadULong +ElfFmtpReadUShort +ElfFmtpSafeReadULong64 +ElfFmtpSafeReadULong +ElfFmtpIsPowerOf2 +ElfFmtpModPow2 +ElfFmtpAlignDown +ElfFmtpAlignUp +Elf64FmtCreateSection + +ntoskrnl/mm/pool.c + +ExAllocatePoolWithTagPriority +ExAllocatePoolWithQuotaTag +ExQueryPoolBlockSize +MmAllocateMappingAddress +MmFreeMappingAddress +MiRaisePoolQuota + +ntoskrnl/mm/wset.c + +MmTrimAllSystemPagableMemory + +ntoskrnl/mm/physical.c + +MmAddPhysicalMemory +MmMarkPhysicalMemoryAsBad +MmMarkPhysicalMemoryAsGood +MmRemovePhysicalMemory +MmGetPhysicalMemoryRanges + +ntoskrnl/mm/section.c + +MmInitSectionImplementation +ExeFmtpAllocateSegments +ExeFmtpReadFile +MmspAssertSegmentsSorted +MmspAssertSegmentsNoOverlap +MmspAssertSegmentsPageAligned +MmspCompareSegments +MmspSortSegments +MmspCheckSegmentBounds +MmspPageAlignSegments +ExeFmtpCreateImageSection +MmCreateImageSection +MmMapViewInSessionSpace +MmUnmapViewInSessionSpace + +ntoskrnl/mm/npool.c + +MiAllocateSpecialPool + +ntoskrnl/mm/elf32.c + +ElfFmtCreateSection + +ntoskrnl/mm/process.c + +MmGrowKernelStack + +ntoskrnl/mm/verifier.c + +MmAddVerifierThunks +MmIsDriverVerifying +MmIsVerifierEnabled + +ntoskrnl/mm/anonmem.c + +NtAllocateVirtualMemory + +ntoskrnl/mm/mdl.c + +MmAdvanceMdl +MmMapLockedPagesWithReservedMapping +MmUnmapReservedMapping +MmPrefetchPages +MmProtectMdlSystemAddress +MmProbeAndLockProcessPages +MmProbeAndLockSelectedPages + +ntoskrnl/mm/paging.c + +MmMapUserAddressesToPage + +ntoskrnl/ob/object.c + +ObpCaptureObjectName +ObpCaptureObjectAttributes +ObQueryNameString +ObpAllocateObject +ObCreateObject +ObpDeleteObject +ObpDeleteObjectWorkRoutine +ObInitializeFastReference +ObFastReferenceObject +ObFastDereferenceObject +ObFastReplaceObject + +ntoskrnl/ob/security.c + +ObLogSecurityDescriptor + +ntoskrnl/ob/wait.c + +NtWaitForMultipleObjects +NtWaitForSingleObject +NtSignalAndWaitForSingleObject + +ntoskrnl/ob/symlink.c + +ObInitSymbolicLinkImplementation + +ntoskrnl/ob/handle.c + +ObInsertObject + +ntoskrnl/ob/namespc.c + +ObReferenceObjectByName +ObQueryDeviceMapInformation +ObpCreateDirectory +ObInit +ObpCreateTypeObject + +ntoskrnl/po/power.c + +NtInitiatePowerAction + +ntoskrnl/ps/win32.c + +PsEstablishWin32Callouts +PsConvertToGuiThread + +ntoskrnl/ps/quota.c + +PsChargePoolQuota +PsChargeProcessNonPagedPoolQuota +PsChargeProcessPagedPoolQuota +PsChargeProcessPoolQuota +PsReturnPoolQuota +PsReturnProcessNonPagedPoolQuota +PsReturnProcessPagedPoolQuota + +ntoskrnl/ps/security.c + +PspLockProcessSecurityShared +PspUnlockProcessSecurityShared +NtOpenProcessToken +NtOpenProcessTokenEx +PsReferencePrimaryToken +PsOpenTokenOfProcess +PspInitializeProcessSecurity +PspAssignPrimaryToken +PsAssignImpersonationToken +PsRevertToSelf +PsRevertThreadToSelf +PsImpersonateClient +PsReferenceEffectiveToken +NtImpersonateThread +PsReferenceImpersonationToken +PsDereferenceImpersonationToken +PsDereferencePrimaryToken +PsDisableImpersonation +PsRestoreImpersonation + +ntoskrnl/ps/thread.c + +PspThreadSpecialApc +PspUserThreadStartup +PspSystemThreadStartup +PspCreateThread +PsCreateSystemThread +PsLookupThreadByThreadId +PsGetThreadFreezeCount +PsGetThreadHardErrorsAreDisabled +PsGetThreadId +PsGetThreadProcess +PsGetThreadProcessId +PsGetThreadSessionId +PsGetThreadTeb +PsGetThreadWin32Thread +PsGetCurrentThreadPreviousMode +PsGetCurrentThreadStackBase +PsGetCurrentThreadStackLimit +PsIsThreadTerminating +PsIsSystemThread +PsIsThreadImpersonating +PsSetThreadHardErrorsAreDisabled +PsSetThreadWin32Thread +NtCreateThread +NtOpenThread +NtYieldExecution +NtTestAlert + +ntoskrnl/ps/query.c + +NtQueryInformationProcess +NtSetInformationProcess +PiQuerySystemProcessInformation +NtSetInformationThread +NtQueryInformationThread + +ntoskrnl/ps/notify.c + +PsSetCreateProcessNotifyRoutine +PsSetLegoNotifyRoutine +PsRemoveLoadImageNotifyRoutine +PsSetLoadImageNotifyRoutine +PsRemoveCreateThreadNotifyRoutine +PsSetCreateThreadNotifyRoutine +PspRunCreateThreadNotifyRoutines +PspRunCreateProcessNotifyRoutines +PspRunLoadImageNotifyRoutines +PspRunLegoRoutine + +ntoskrnl/ps/suspend.c + +NtResumeThread +NtSuspendThread + +ntoskrnl/ps/job.c + +PsInitJobManagment +NtQueryInformationJobObject +NtSetInformationJobObject +PsGetJobLock +PsGetJobSessionId +PsGetJobUIRestrictionsClass +PsSetJobUIRestrictionsClass + +ntoskrnl/ps/idle.c + +PsInitializeIdleOrFirstThread +PsInitIdleThread + +ntoskrnl/ps/process.c + +PsLockProcess +PsUnlockProcess +PsGetNextProcess +PspCreateProcess +PsCreateSystemProcess +PsLookupProcessByProcessId +PsLookupProcessThreadByCid +PsGetProcessDebugPort +PsGetProcessExitProcessCalled +PsGetProcessExitStatus +PsGetProcessId +PsGetProcessImageFileName +PsGetProcessInheritedFromUniqueProcessId +PsGetProcessJob +PsGetProcessPeb +PsGetProcessPriorityClass +PsGetCurrentProcessId +PsGetCurrentProcessSessionId +PsGetProcessSectionBaseAddress +PsGetProcessSecurityPort +PsGetProcessSessionId +PsGetWin32Thread +PsGetWin32Process +PsGetProcessWin32Process +PsGetProcessWin32WindowStation +PsIsProcessBeingDebugged +PsSetProcessPriorityClass +PsSetProcessSecurityPort +PsSetProcessWin32Process +PsSetProcessWindowStation +NtCreateProcess + +ntoskrnl/ps/psmgr.c + +PsInitClientIDManagment +PsInitThreadManagment +PsInitProcessManagment +PspPostInitSystemProcess +PspLookupKernelUserEntryPoints +PspMapSystemDll +PsLocateSystemDll +PsGetVersion + +ntoskrnl/ps/kill.c + +PspReapRoutine +PspKillMostProcesses +PspTerminateProcessThreads +PspDeleteProcess +PspDeleteThread +PspExitThread +PsExitSpecialApc +PspExitNormalApc +PspTerminateThreadByPointer +NtTerminateThread +PsTerminateSystemThread +NtRegisterThreadTerminatePort + +ntoskrnl/ps/debug.c + +PspGetOrSetContextKernelRoutine +NtGetContextThread +NtSetContextThread +PspDumpThreads + +ntoskrnl/rtl/libsupp.c + +RtlpCheckForActiveDebugger +RtlpSetInDbgPrint +RtlAcquirePebLock +RtlReleasePebLock +LdrShutdownThread +RtlpCurrentPeb +RtlpCheckLogException +RtlpHandleDpcStackException + +ntoskrnl/rtl/misc.c + +DebugPrint + +ntoskrnl/se/semgr.c + +SepInitExports +SeDefaultObjectMethod +SeAssignSecurityEx + +ntoskrnl/se/access.c + +SeCreateAccessState +SeDeleteAccessState +SeSetAccessStateGenericMapping + +ntoskrnl/se/sd.c + +SeSetWorldSecurityDescriptor +SeSetSecurityDescriptorInfoEx + +ntoskrnl/se/token.c + +SeExchangePrimaryToken +SeDeassignPrimaryToken +SeAppendPrivileges +SeCreateClientSecurityFromSubjectContext +SeFilterToken +SeFreePrivileges +SeImpersonateClientEx +SepInitializeTokenImplementation +SeQueryInformationToken +SeQuerySessionIdToken +SeTokenIsAdmin +SeTokenIsRestricted +SeTokenIsWriteRestricted + +ntoskrnl/se/audit.c + +SeAuditHardLinkCreation +SeAuditingFileEvents +SeAuditingFileEventsWithContext +SeAuditingHardLinkEvents +SeAuditingHardLinkEventsWithContext +SeAuditingFileOrGlobalEvents +SeCloseObjectAuditAlarm +SePrivilegeObjectAuditAlarm + +ntoskrnl/se/lsa.c + +SeMarkLogonSessionForTerminationNotification +SeRegisterLogonSessionTerminatedRoutine +SeUnregisterLogonSessionTerminatedRoutine
Propchange: branches/ntoskrnl-audit/reactos/ntoskrnl/function_list.txt ------------------------------------------------------------------------------ svn:eol-style = native