/* * Copyright (C) 2010 The Android Open Source Project * * Licensed under the Apache License, Version 2.0 (the "License"); * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * * http://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. * See the License for the specific language governing permissions and * limitations under the License. */ #pragma once #include "AnrTracker.h" #include "CancelationOptions.h" #include "DragState.h" #include "Entry.h" #include "FocusResolver.h" #include "InjectionState.h" #include "InputDispatcherConfiguration.h" #include "InputDispatcherInterface.h" #include "InputDispatcherPolicyInterface.h" #include "InputTarget.h" #include "InputThread.h" #include "LatencyAggregator.h" #include "LatencyTracker.h" #include "Monitor.h" #include "TouchState.h" #include "TouchedWindow.h" #include "trace/InputTracerInterface.h" #include "trace/InputTracingBackendInterface.h" #include #include #include #include #include #include #include #include #include #include #include #include #include #include #include #include #include #include #include #include #include #include namespace android::inputdispatcher { class Connection; /* Dispatches events to input targets. Some functions of the input dispatcher, such as * identifying input targets, are controlled by a separate policy object. * * IMPORTANT INVARIANT: * Because the policy can potentially block or cause re-entrance into the input dispatcher, * the input dispatcher never calls into the policy while holding its internal locks. * The implementation is also carefully designed to recover from scenarios such as an * input channel becoming unregistered while identifying input targets or processing timeouts. * * Methods marked 'Locked' must be called with the lock acquired. * * Methods marked 'LockedInterruptible' must be called with the lock acquired but * may during the course of their execution release the lock, call into the policy, and * then reacquire the lock. The caller is responsible for recovering gracefully. * * A 'LockedInterruptible' method may called a 'Locked' method, but NOT vice-versa. */ class InputDispatcher : public android::InputDispatcherInterface { public: static constexpr bool kDefaultInTouchMode = true; explicit InputDispatcher(InputDispatcherPolicyInterface& policy); // Constructor used for testing. explicit InputDispatcher(InputDispatcherPolicyInterface&, std::unique_ptr); ~InputDispatcher() override; void dump(std::string& dump) const override; void monitor() override; bool waitForIdle() const override; status_t start() override; status_t stop() override; void notifyInputDevicesChanged(const NotifyInputDevicesChangedArgs& args) override; void notifyConfigurationChanged(const NotifyConfigurationChangedArgs& args) override; void notifyKey(const NotifyKeyArgs& args) override; void notifyMotion(const NotifyMotionArgs& args) override; void notifySwitch(const NotifySwitchArgs& args) override; void notifySensor(const NotifySensorArgs& args) override; void notifyVibratorState(const NotifyVibratorStateArgs& args) override; void notifyDeviceReset(const NotifyDeviceResetArgs& args) override; void notifyPointerCaptureChanged(const NotifyPointerCaptureChangedArgs& args) override; android::os::InputEventInjectionResult injectInputEvent( const InputEvent* event, std::optional targetUid, android::os::InputEventInjectionSync syncMode, std::chrono::milliseconds timeout, uint32_t policyFlags) override; std::unique_ptr verifyInputEvent(const InputEvent& event) override; void setFocusedApplication( ui::LogicalDisplayId displayId, const std::shared_ptr& inputApplicationHandle) override; void setFocusedDisplay(ui::LogicalDisplayId displayId) override; void setMinTimeBetweenUserActivityPokes(std::chrono::milliseconds interval) override; void setInputDispatchMode(bool enabled, bool frozen) override; void setInputFilterEnabled(bool enabled) override; bool setInTouchMode(bool inTouchMode, gui::Pid pid, gui::Uid uid, bool hasPermission, ui::LogicalDisplayId displayId) override; void setMaximumObscuringOpacityForTouch(float opacity) override; bool transferTouchGesture(const sp& fromToken, const sp& toToken, bool isDragDrop = false) override; bool transferTouchOnDisplay(const sp& destChannelToken, ui::LogicalDisplayId displayId) override; base::Result> createInputChannel( const std::string& name) override; void setFocusedWindow(const android::gui::FocusRequest&) override; base::Result> createInputMonitor(ui::LogicalDisplayId displayId, const std::string& name, gui::Pid pid) override; status_t removeInputChannel(const sp& connectionToken) override; status_t pilferPointers(const sp& token) override; void requestPointerCapture(const sp& windowToken, bool enabled) override; bool flushSensor(int deviceId, InputDeviceSensorType sensorType) override; void setDisplayEligibilityForPointerCapture(ui::LogicalDisplayId displayId, bool isEligible) override; std::array sign(const VerifiedInputEvent& event) const; void displayRemoved(ui::LogicalDisplayId displayId) override; // Public because it's also used by tests to simulate the WindowInfosListener callback void onWindowInfosChanged(const gui::WindowInfosUpdate&); void cancelCurrentTouch() override; // Public to allow tests to verify that a Monitor can get ANR. void setMonitorDispatchingTimeoutForTest(std::chrono::nanoseconds timeout); void setKeyRepeatConfiguration(std::chrono::nanoseconds timeout, std::chrono::nanoseconds delay) override; bool isPointerInWindow(const sp& token, ui::LogicalDisplayId displayId, DeviceId deviceId, int32_t pointerId) override; void setInputMethodConnectionIsActive(bool isActive) override; private: enum class DropReason { NOT_DROPPED, POLICY, DISABLED, BLOCKED, STALE, NO_POINTER_CAPTURE, }; std::unique_ptr mThread; InputDispatcherPolicyInterface& mPolicy; android::InputDispatcherConfiguration mConfig GUARDED_BY(mLock); mutable std::mutex mLock; std::condition_variable mDispatcherIsAlive; mutable std::condition_variable mDispatcherEnteredIdle; // Input event tracer. The tracer will only exist on builds where input tracing is allowed. std::unique_ptr mTracer GUARDED_BY(mLock); sp mLooper; std::shared_ptr mPendingEvent GUARDED_BY(mLock); std::deque> mInboundQueue GUARDED_BY(mLock); std::deque> mRecentQueue GUARDED_BY(mLock); // A command entry captures state and behavior for an action to be performed in the // dispatch loop after the initial processing has taken place. It is essentially // a kind of continuation used to postpone sensitive policy interactions to a point // in the dispatch loop where it is safe to release the lock (generally after finishing // the critical parts of the dispatch cycle). // // The special thing about commands is that they can voluntarily release and reacquire // the dispatcher lock at will. Initially when the command starts running, the // dispatcher lock is held. However, if the command needs to call into the policy to // do some work, it can release the lock, do the work, then reacquire the lock again // before returning. // // This mechanism is a bit clunky but it helps to preserve the invariant that the dispatch // never calls into the policy while holding its lock. // // Commands are called with the lock held, but they can release and re-acquire the lock from // within. using Command = std::function; std::deque mCommandQueue GUARDED_BY(mLock); DropReason mLastDropReason GUARDED_BY(mLock); const IdGenerator mIdGenerator GUARDED_BY(mLock); int64_t mWindowInfosVsyncId GUARDED_BY(mLock); std::chrono::milliseconds mMinTimeBetweenUserActivityPokes GUARDED_BY(mLock); /** Stores the latest user-activity poke event times per user activity types. */ std::array mLastUserActivityTimes GUARDED_BY(mLock); // With each iteration, InputDispatcher nominally processes one queued event, // a timeout, or a response from an input consumer. // This method should only be called on the input dispatcher's own thread. void dispatchOnce(); void dispatchOnceInnerLocked(nsecs_t& nextWakeupTime) REQUIRES(mLock); // Enqueues an inbound event. Returns true if mLooper->wake() should be called. bool enqueueInboundEventLocked(std::unique_ptr entry) REQUIRES(mLock); // Cleans up input state when dropping an inbound event. void dropInboundEventLocked(const EventEntry& entry, DropReason dropReason) REQUIRES(mLock); // Enqueues a focus event. void enqueueFocusEventLocked(const sp& windowToken, bool hasFocus, const std::string& reason) REQUIRES(mLock); // Enqueues a drag event. void enqueueDragEventLocked(const sp& windowToken, bool isExiting, const int32_t rawX, const int32_t rawY) REQUIRES(mLock); // Adds an event to a queue of recent events for debugging purposes. void addRecentEventLocked(std::shared_ptr entry) REQUIRES(mLock); // Blocked event latency optimization. Drops old events when the user intends // to transfer focus to a new application. std::shared_ptr mNextUnblockedEvent GUARDED_BY(mLock); sp findTouchedWindowAtLocked( ui::LogicalDisplayId displayId, float x, float y, bool isStylus = false, bool ignoreDragWindow = false) const REQUIRES(mLock); std::vector findOutsideTargetsLocked( ui::LogicalDisplayId displayId, const sp& touchedWindow, int32_t pointerId) const REQUIRES(mLock); std::vector> findTouchedSpyWindowsAtLocked( ui::LogicalDisplayId displayId, float x, float y, bool isStylus) const REQUIRES(mLock); sp findTouchedForegroundWindowLocked( ui::LogicalDisplayId displayId) const REQUIRES(mLock); std::shared_ptr getConnectionLocked(const sp& inputConnectionToken) const REQUIRES(mLock); std::string getConnectionNameLocked(const sp& connectionToken) const REQUIRES(mLock); void removeConnectionLocked(const std::shared_ptr& connection) REQUIRES(mLock); status_t pilferPointersLocked(const sp& token) REQUIRES(mLock); template struct StrongPointerHash { std::size_t operator()(const sp& b) const { return std::hash{}(b.get()); } }; // All registered connections mapped by input channel token. std::unordered_map, std::shared_ptr, StrongPointerHash> mConnectionsByToken GUARDED_BY(mLock); // Find a monitor pid by the provided token. std::optional findMonitorPidByTokenLocked(const sp& token) REQUIRES(mLock); // Input channels that will receive a copy of all input events sent to the provided display. std::unordered_map> mGlobalMonitorsByDisplay GUARDED_BY(mLock); const HmacKeyManager mHmacKeyManager; const std::array getSignature(const MotionEntry& motionEntry, const DispatchEntry& dispatchEntry) const; const std::array getSignature(const KeyEntry& keyEntry, const DispatchEntry& dispatchEntry) const; // Event injection and synchronization. std::condition_variable mInjectionResultAvailable; void setInjectionResult(const EventEntry& entry, android::os::InputEventInjectionResult injectionResult); void transformMotionEntryForInjectionLocked(MotionEntry&, const ui::Transform& injectedTransform) const REQUIRES(mLock); // Per-display correction of injected events std::map mInputFilterVerifiersByDisplay GUARDED_BY(mLock); std::condition_variable mInjectionSyncFinished; void incrementPendingForegroundDispatches(const EventEntry& entry); void decrementPendingForegroundDispatches(const EventEntry& entry); // Key repeat tracking. struct KeyRepeatState { std::shared_ptr lastKeyEntry; // or null if no repeat nsecs_t nextRepeatTime; } mKeyRepeatState GUARDED_BY(mLock); void resetKeyRepeatLocked() REQUIRES(mLock); std::shared_ptr synthesizeKeyRepeatLocked(nsecs_t currentTime) REQUIRES(mLock); // Deferred command processing. bool haveCommandsLocked() const REQUIRES(mLock); bool runCommandsLockedInterruptable() REQUIRES(mLock); void postCommandLocked(Command&& command) REQUIRES(mLock); // The dispatching timeout to use for Monitors. std::chrono::nanoseconds mMonitorDispatchingTimeout GUARDED_BY(mLock); nsecs_t processAnrsLocked() REQUIRES(mLock); std::chrono::nanoseconds getDispatchingTimeoutLocked( const std::shared_ptr& connection) REQUIRES(mLock); // Input filter processing. bool shouldSendKeyToInputFilterLocked(const NotifyKeyArgs& args) REQUIRES(mLock); bool shouldSendMotionToInputFilterLocked(const NotifyMotionArgs& args) REQUIRES(mLock); // Inbound event processing. void drainInboundQueueLocked() REQUIRES(mLock); void releasePendingEventLocked() REQUIRES(mLock); void releaseInboundEventLocked(std::shared_ptr entry) REQUIRES(mLock); // Dispatch state. bool mDispatchEnabled GUARDED_BY(mLock); bool mDispatchFrozen GUARDED_BY(mLock); bool mInputFilterEnabled GUARDED_BY(mLock); float mMaximumObscuringOpacityForTouch GUARDED_BY(mLock); // This map is not really needed, but it helps a lot with debugging (dumpsys input). // In the java layer, touch mode states are spread across multiple DisplayContent objects, // making harder to snapshot and retrieve them. std::map mTouchModePerDisplay GUARDED_BY(mLock); class DispatcherWindowListener : public gui::WindowInfosListener { public: explicit DispatcherWindowListener(InputDispatcher& dispatcher) : mDispatcher(dispatcher){}; void onWindowInfosChanged(const gui::WindowInfosUpdate&) override; private: InputDispatcher& mDispatcher; }; sp mWindowInfoListener; std::unordered_map>> mWindowHandlesByDisplay GUARDED_BY(mLock); std::unordered_map mDisplayInfos GUARDED_BY(mLock); void setInputWindowsLocked( const std::vector>& inputWindowHandles, ui::LogicalDisplayId displayId) REQUIRES(mLock); // Get a reference to window handles by display, return an empty vector if not found. const std::vector>& getWindowHandlesLocked( ui::LogicalDisplayId displayId) const REQUIRES(mLock); ui::Transform getTransformLocked(ui::LogicalDisplayId displayId) const REQUIRES(mLock); sp getWindowHandleLocked( const sp& windowHandleToken, std::optional displayId = {}) const REQUIRES(mLock); sp getWindowHandleLocked( const sp& windowHandle) const REQUIRES(mLock); sp getFocusedWindowHandleLocked( ui::LogicalDisplayId displayId) const REQUIRES(mLock); bool canWindowReceiveMotionLocked(const sp& window, const MotionEntry& motionEntry) const REQUIRES(mLock); // Returns all the input targets (with their respective input channels) from the window handles // passed as argument. std::vector getInputTargetsFromWindowHandlesLocked( const std::vector>& windowHandles) const REQUIRES(mLock); /* * Validate and update InputWindowHandles for a given display. */ void updateWindowHandlesForDisplayLocked( const std::vector>& inputWindowHandles, ui::LogicalDisplayId displayId) REQUIRES(mLock); std::unordered_map mTouchStatesByDisplay GUARDED_BY(mLock); std::unique_ptr mDragState GUARDED_BY(mLock); void setFocusedApplicationLocked( ui::LogicalDisplayId displayId, const std::shared_ptr& inputApplicationHandle) REQUIRES(mLock); // Focused applications. std::unordered_map> mFocusedApplicationHandlesByDisplay GUARDED_BY(mLock); // Top focused display. ui::LogicalDisplayId mFocusedDisplayId GUARDED_BY(mLock); // Keeps track of the focused window per display and determines focus changes. FocusResolver mFocusResolver GUARDED_BY(mLock); // The enabled state of this request is true iff the focused window on the focused display has // requested Pointer Capture. This request also contains the sequence number associated with the // current request. The state of this variable should always be in sync with the state of // Pointer Capture in the policy, and is only updated through setPointerCaptureLocked(request). PointerCaptureRequest mCurrentPointerCaptureRequest GUARDED_BY(mLock); // The window token that has Pointer Capture. // This should be in sync with PointerCaptureChangedEvents dispatched to the input channel. sp mWindowTokenWithPointerCapture GUARDED_BY(mLock); // Displays that are ineligible for pointer capture. // TODO(b/214621487): Remove or move to a display flag. std::vector mIneligibleDisplaysForPointerCapture GUARDED_BY(mLock); // Disable Pointer Capture as a result of loss of window focus. void disablePointerCaptureForcedLocked() REQUIRES(mLock); // Set the Pointer Capture state in the Policy. // The window is not nullptr for requests to enable, otherwise it is nullptr. void setPointerCaptureLocked(const sp& window) REQUIRES(mLock); // Dispatcher state at time of last ANR. std::string mLastAnrState GUARDED_BY(mLock); // The connection tokens of the channels that the user last interacted (used for debugging and // when switching touch mode state). std::unordered_set, StrongPointerHash> mInteractionConnectionTokens GUARDED_BY(mLock); void processInteractionsLocked(const EventEntry& entry, const std::vector& targets) REQUIRES(mLock); // Dispatch inbound events. bool dispatchConfigurationChangedLocked(nsecs_t currentTime, const ConfigurationChangedEntry& entry) REQUIRES(mLock); bool dispatchDeviceResetLocked(nsecs_t currentTime, const DeviceResetEntry& entry) REQUIRES(mLock); bool dispatchKeyLocked(nsecs_t currentTime, std::shared_ptr entry, DropReason* dropReason, nsecs_t& nextWakeupTime) REQUIRES(mLock); bool dispatchMotionLocked(nsecs_t currentTime, std::shared_ptr entry, DropReason* dropReason, nsecs_t& nextWakeupTime) REQUIRES(mLock); void dispatchFocusLocked(nsecs_t currentTime, std::shared_ptr entry) REQUIRES(mLock); void dispatchPointerCaptureChangedLocked( nsecs_t currentTime, const std::shared_ptr& entry, DropReason& dropReason) REQUIRES(mLock); void dispatchTouchModeChangeLocked(nsecs_t currentTime, const std::shared_ptr& entry) REQUIRES(mLock); void dispatchEventLocked(nsecs_t currentTime, std::shared_ptr entry, const std::vector& inputTargets) REQUIRES(mLock); void dispatchSensorLocked(nsecs_t currentTime, const std::shared_ptr& entry, DropReason* dropReason, nsecs_t& nextWakeupTime) REQUIRES(mLock); void dispatchDragLocked(nsecs_t currentTime, std::shared_ptr entry) REQUIRES(mLock); void logOutboundKeyDetails(const char* prefix, const KeyEntry& entry); void logOutboundMotionDetails(const char* prefix, const MotionEntry& entry); /** * This field is set if there is no focused window, and we have an event that requires * a focused window to be dispatched (for example, a KeyEvent). * When this happens, we will wait until *mNoFocusedWindowTimeoutTime before * dropping the event and raising an ANR for that application. * This is useful if an application is slow to add a focused window. */ std::optional mNoFocusedWindowTimeoutTime GUARDED_BY(mLock); bool isStaleEvent(nsecs_t currentTime, const EventEntry& entry); bool shouldPruneInboundQueueLocked(const MotionEntry& motionEntry) const REQUIRES(mLock); /** * Time to stop waiting for the events to be processed while trying to dispatch a key. * When this time expires, we just send the pending key event to the currently focused window, * without waiting on other events to be processed first. */ std::optional mKeyIsWaitingForEventsTimeout GUARDED_BY(mLock); bool shouldWaitToSendKeyLocked(nsecs_t currentTime, const char* focusedWindowName) REQUIRES(mLock); /** * The focused application at the time when no focused window was present. * Used to raise an ANR when we have no focused window. */ std::shared_ptr mAwaitedFocusedApplication GUARDED_BY(mLock); /** * The displayId that the focused application is associated with. */ ui::LogicalDisplayId mAwaitedApplicationDisplayId GUARDED_BY(mLock); void processNoFocusedWindowAnrLocked() REQUIRES(mLock); /** * Tell policy about a window or a monitor that just became unresponsive. Starts ANR. */ void processConnectionUnresponsiveLocked(const Connection& connection, std::string reason) REQUIRES(mLock); /** * Tell policy about a window or a monitor that just became responsive. */ void processConnectionResponsiveLocked(const Connection& connection) REQUIRES(mLock); void sendWindowUnresponsiveCommandLocked(const sp& connectionToken, std::optional pid, std::string reason) REQUIRES(mLock); void sendWindowResponsiveCommandLocked(const sp& connectionToken, std::optional pid) REQUIRES(mLock); // Optimization: AnrTracker is used to quickly find which connection is due for a timeout next. // AnrTracker must be kept in-sync with all responsive connection.waitQueues. // If a connection is not responsive, then the entries should not be added to the AnrTracker. // Once a connection becomes unresponsive, its entries are removed from AnrTracker to // prevent unneeded wakeups. AnrTracker mAnrTracker GUARDED_BY(mLock); void cancelEventsForAnrLocked(const std::shared_ptr& connection) REQUIRES(mLock); // If a focused application changes, we should stop counting down the "no focused window" time, // because we will have no way of knowing when the previous application actually added a window. // This also means that we will miss cases like pulling down notification shade when the // focused application does not have a focused window (no ANR will be raised if notification // shade is pulled down while we are counting down the timeout). void resetNoFocusedWindowTimeoutLocked() REQUIRES(mLock); ui::LogicalDisplayId getTargetDisplayId(const EventEntry& entry); sp findFocusedWindowTargetLocked( nsecs_t currentTime, const EventEntry& entry, nsecs_t& nextWakeupTime, android::os::InputEventInjectionResult& outInjectionResult) REQUIRES(mLock); std::vector findTouchedWindowTargetsLocked( nsecs_t currentTime, const MotionEntry& entry, android::os::InputEventInjectionResult& outInjectionResult) REQUIRES(mLock); std::vector selectResponsiveMonitorsLocked( const std::vector& gestureMonitors) const REQUIRES(mLock); std::optional createInputTargetLocked( const sp& windowHandle, InputTarget::DispatchMode dispatchMode, ftl::Flags targetFlags, std::optional firstDownTimeInTarget) const REQUIRES(mLock); void addWindowTargetLocked(const sp& windowHandle, InputTarget::DispatchMode dispatchMode, ftl::Flags targetFlags, std::optional firstDownTimeInTarget, std::vector& inputTargets) const REQUIRES(mLock); void addPointerWindowTargetLocked(const sp& windowHandle, InputTarget::DispatchMode dispatchMode, ftl::Flags targetFlags, std::bitset pointerIds, std::optional firstDownTimeInTarget, std::vector& inputTargets) const REQUIRES(mLock); void addGlobalMonitoringTargetsLocked(std::vector& inputTargets, ui::LogicalDisplayId displayId) REQUIRES(mLock); void pokeUserActivityLocked(const EventEntry& eventEntry) REQUIRES(mLock); // Enqueue a drag event if needed, and update the touch state. // Uses findTouchedWindowTargetsLocked to make the decision void addDragEventLocked(const MotionEntry& entry) REQUIRES(mLock); void finishDragAndDrop(ui::LogicalDisplayId displayId, float x, float y) REQUIRES(mLock); struct TouchOcclusionInfo { bool hasBlockingOcclusion; float obscuringOpacity; std::string obscuringPackage; gui::Uid obscuringUid = gui::Uid::INVALID; std::vector debugInfo; }; TouchOcclusionInfo computeTouchOcclusionInfoLocked( const sp& windowHandle, float x, float y) const REQUIRES(mLock); bool isTouchTrustedLocked(const TouchOcclusionInfo& occlusionInfo) const REQUIRES(mLock); bool isWindowObscuredAtPointLocked(const sp& windowHandle, float x, float y) const REQUIRES(mLock); bool isWindowObscuredLocked(const sp& windowHandle) const REQUIRES(mLock); std::string dumpWindowForTouchOcclusion(const android::gui::WindowInfo* info, bool isTouchWindow) const; std::string getApplicationWindowLabel(const InputApplicationHandle* applicationHandle, const sp& windowHandle); bool shouldDropInput(const EventEntry& entry, const sp& windowHandle) const REQUIRES(mLock); // Manage the dispatch cycle for a single connection. // These methods are deliberately not Interruptible because doing all of the work // with the mutex held makes it easier to ensure that connection invariants are maintained. // If needed, the methods post commands to run later once the critical bits are done. void prepareDispatchCycleLocked(nsecs_t currentTime, const std::shared_ptr& connection, std::shared_ptr, const InputTarget& inputTarget) REQUIRES(mLock); void enqueueDispatchEntryAndStartDispatchCycleLocked( nsecs_t currentTime, const std::shared_ptr& connection, std::shared_ptr, const InputTarget& inputTarget) REQUIRES(mLock); void enqueueDispatchEntryLocked(const std::shared_ptr& connection, std::shared_ptr, const InputTarget& inputTarget) REQUIRES(mLock); status_t publishMotionEvent(Connection& connection, DispatchEntry& dispatchEntry) const; void startDispatchCycleLocked(nsecs_t currentTime, const std::shared_ptr& connection) REQUIRES(mLock); void finishDispatchCycleLocked(nsecs_t currentTime, const std::shared_ptr& connection, uint32_t seq, bool handled, nsecs_t consumeTime) REQUIRES(mLock); void abortBrokenDispatchCycleLocked(nsecs_t currentTime, const std::shared_ptr& connection, bool notify) REQUIRES(mLock); void drainDispatchQueue(std::deque>& queue); void releaseDispatchEntry(std::unique_ptr dispatchEntry); int handleReceiveCallback(int events, sp connectionToken); // The action sent should only be of type AMOTION_EVENT_* void dispatchPointerDownOutsideFocus(uint32_t source, int32_t action, const sp& newToken) REQUIRES(mLock); void synthesizeCancelationEventsForAllConnectionsLocked(const CancelationOptions& options) REQUIRES(mLock); void synthesizeCancelationEventsForMonitorsLocked(const CancelationOptions& options) REQUIRES(mLock); void synthesizeCancelationEventsForWindowLocked(const sp&, const CancelationOptions&, const std::shared_ptr& = nullptr) REQUIRES(mLock); // This is a convenience function used to generate cancellation for a connection without having // to check whether it's a monitor or a window. For non-monitors, the window handle must not be // null. Always prefer the "-ForWindow" method above when explicitly dealing with windows. void synthesizeCancelationEventsForConnectionLocked( const std::shared_ptr& connection, const CancelationOptions& options, const sp& window) REQUIRES(mLock); void synthesizePointerDownEventsForConnectionLocked( const nsecs_t downTime, const std::shared_ptr& connection, ftl::Flags targetFlags, const std::unique_ptr& traceTracker) REQUIRES(mLock); // Splitting motion events across windows. When splitting motion event for a target, // splitDownTime refers to the time of first 'down' event on that particular target std::unique_ptr splitMotionEvent(const MotionEntry& originalMotionEntry, std::bitset pointerIds, nsecs_t splitDownTime) REQUIRES(mLock); // Reset and drop everything the dispatcher is doing. void resetAndDropEverythingLocked(const char* reason) REQUIRES(mLock); // Dump state. void dumpDispatchStateLocked(std::string& dump) const REQUIRES(mLock); void dumpMonitors(std::string& dump, const std::vector& monitors) const; void logDispatchStateLocked() const REQUIRES(mLock); std::string dumpPointerCaptureStateLocked() const REQUIRES(mLock); // Registration. void removeMonitorChannelLocked(const sp& connectionToken) REQUIRES(mLock); status_t removeInputChannelLocked(const sp& connectionToken, bool notify) REQUIRES(mLock); // Interesting events that we might like to log or tell the framework about. void doDispatchCycleFinishedCommand(nsecs_t finishTime, const std::shared_ptr& connection, uint32_t seq, bool handled, nsecs_t consumeTime) REQUIRES(mLock); void doInterceptKeyBeforeDispatchingCommand(const sp& focusedWindowToken, const KeyEntry& entry) REQUIRES(mLock); void onFocusChangedLocked(const FocusResolver::FocusChanges& changes, const std::unique_ptr& traceTracker, const sp removedFocusedWindowHandle = nullptr) REQUIRES(mLock); void sendFocusChangedCommandLocked(const sp& oldToken, const sp& newToken) REQUIRES(mLock); void sendDropWindowCommandLocked(const sp& token, float x, float y) REQUIRES(mLock); void onAnrLocked(const std::shared_ptr& connection) REQUIRES(mLock); void onAnrLocked(std::shared_ptr application) REQUIRES(mLock); void updateLastAnrStateLocked(const sp& window, const std::string& reason) REQUIRES(mLock); void updateLastAnrStateLocked(const InputApplicationHandle& application, const std::string& reason) REQUIRES(mLock); void updateLastAnrStateLocked(const std::string& windowLabel, const std::string& reason) REQUIRES(mLock); std::map mVerifiersByDisplay; // Returns a fallback KeyEntry that should be sent to the connection, if required. std::unique_ptr afterKeyEventLockedInterruptable( const std::shared_ptr& connection, DispatchEntry* dispatchEntry, bool handled) REQUIRES(mLock); // Find touched state and touched window by token. std::tuple findTouchStateWindowAndDisplayLocked(const sp& token) REQUIRES(mLock); // Statistics gathering. LatencyAggregator mLatencyAggregator GUARDED_BY(mLock); LatencyTracker mLatencyTracker GUARDED_BY(mLock); void traceInboundQueueLengthLocked() REQUIRES(mLock); void traceOutboundQueueLength(const Connection& connection); void traceWaitQueueLength(const Connection& connection); // Check window ownership bool focusedWindowIsOwnedByLocked(gui::Pid pid, gui::Uid uid) REQUIRES(mLock); bool recentWindowsAreOwnedByLocked(gui::Pid pid, gui::Uid uid) REQUIRES(mLock); sp mReporter; void slipWallpaperTouch(ftl::Flags targetFlags, const sp& oldWindowHandle, const sp& newWindowHandle, TouchState& state, DeviceId deviceId, const PointerProperties& pointerProperties, std::vector& targets) const REQUIRES(mLock); void transferWallpaperTouch(ftl::Flags oldTargetFlags, ftl::Flags newTargetFlags, const sp fromWindowHandle, const sp toWindowHandle, TouchState& state, DeviceId deviceId, const std::vector& pointers, const std::unique_ptr& traceTracker) REQUIRES(mLock); sp findWallpaperWindowBelow( const sp& windowHandle) const REQUIRES(mLock); }; } // namespace android::inputdispatcher