| 123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300 |
- /*
- * Copyright 2020, gRPC Authors All rights reserved.
- *
- * 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.
- */
- import Logging
- import NIO
- import NIOHTTP2
- internal final class GRPCIdleHandler: ChannelInboundHandler {
- typealias InboundIn = HTTP2Frame
- typealias OutboundOut = HTTP2Frame
- /// The amount of time to wait before closing the channel when there are no active streams.
- private let idleTimeout: TimeAmount
- /// The ping handler.
- private var pingHandler: PingHandler
- /// The scheduled task which will close the connection after the keep-alive timeout has expired.
- private var scheduledClose: Scheduled<Void>?
- /// The scheduled task which will ping.
- private var scheduledPing: RepeatedTask?
- /// The mode we're operating in.
- private let mode: Mode
- /// A logger.
- private let logger: Logger
- private var context: ChannelHandlerContext?
- /// The mode of operation: the client tracks additional connection state in the connection
- /// manager.
- internal enum Mode {
- case client(ConnectionManager, HTTP2StreamMultiplexer)
- case server
- var connectionManager: ConnectionManager? {
- switch self {
- case let .client(manager, _):
- return manager
- case .server:
- return nil
- }
- }
- }
- /// The current state.
- private var stateMachine: GRPCIdleHandlerStateMachine
- init(
- connectionManager: ConnectionManager,
- multiplexer: HTTP2StreamMultiplexer,
- idleTimeout: TimeAmount,
- keepalive configuration: ClientConnectionKeepalive,
- logger: Logger
- ) {
- self.mode = .client(connectionManager, multiplexer)
- self.idleTimeout = idleTimeout
- self.stateMachine = .init(role: .client, logger: logger)
- self.pingHandler = PingHandler(
- pingCode: 5,
- interval: configuration.interval,
- timeout: configuration.timeout,
- permitWithoutCalls: configuration.permitWithoutCalls,
- maximumPingsWithoutData: configuration.maximumPingsWithoutData,
- minimumSentPingIntervalWithoutData: configuration.minimumSentPingIntervalWithoutData
- )
- self.logger = logger
- }
- init(
- idleTimeout: TimeAmount,
- keepalive configuration: ServerConnectionKeepalive,
- logger: Logger
- ) {
- self.mode = .server
- self.stateMachine = .init(role: .server, logger: logger)
- self.idleTimeout = idleTimeout
- self.pingHandler = PingHandler(
- pingCode: 10,
- interval: configuration.interval,
- timeout: configuration.timeout,
- permitWithoutCalls: configuration.permitWithoutCalls,
- maximumPingsWithoutData: configuration.maximumPingsWithoutData,
- minimumSentPingIntervalWithoutData: configuration.minimumSentPingIntervalWithoutData,
- minimumReceivedPingIntervalWithoutData: configuration.minimumReceivedPingIntervalWithoutData,
- maximumPingStrikes: configuration.maximumPingStrikes
- )
- self.logger = logger
- }
- private func sendGoAway(lastStreamID streamID: HTTP2StreamID) {
- guard let context = self.context else {
- return
- }
- let frame = HTTP2Frame(
- streamID: .rootStream,
- payload: .goAway(lastStreamID: streamID, errorCode: .noError, opaqueData: nil)
- )
- context.writeAndFlush(self.wrapOutboundOut(frame), promise: nil)
- }
- private func perform(operations: GRPCIdleHandlerStateMachine.Operations) {
- // Prod the connection manager.
- if let event = operations.connectionManagerEvent, let manager = self.mode.connectionManager {
- switch event {
- case .idle:
- manager.idle()
- case .inactive:
- manager.channelInactive()
- case .ready:
- manager.ready()
- case .quiescing:
- manager.beginQuiescing()
- }
- }
- // Handle idle timeout creation/cancellation.
- if let idleTask = operations.idleTask {
- switch idleTask {
- case let .cancel(task):
- task.cancel()
- case .schedule:
- if self.idleTimeout != .nanoseconds(.max), let context = self.context {
- let task = context.eventLoop.scheduleTask(in: self.idleTimeout) {
- self.idleTimeoutFired()
- }
- self.perform(operations: self.stateMachine.scheduledIdleTimeoutTask(task))
- }
- }
- }
- // Send a GOAWAY frame.
- if let streamID = operations.sendGoAwayWithLastPeerInitiatedStreamID {
- let goAwayFrame = HTTP2Frame(
- streamID: .rootStream,
- payload: .goAway(lastStreamID: streamID, errorCode: .noError, opaqueData: nil)
- )
- self.context?.writeAndFlush(self.wrapOutboundOut(goAwayFrame), promise: nil)
- }
- // Close the channel, if necessary.
- if operations.shouldCloseChannel {
- self.context?.close(mode: .all, promise: nil)
- }
- }
- private func handlePingAction(_ action: PingHandler.Action) {
- switch action {
- case .none:
- ()
- case .cancelScheduledTimeout:
- self.scheduledClose?.cancel()
- self.scheduledClose = nil
- case let .schedulePing(delay, timeout):
- self.schedulePing(in: delay, timeout: timeout)
- case let .reply(framePayload):
- let frame = HTTP2Frame(streamID: .rootStream, payload: framePayload)
- self.context?.writeAndFlush(self.wrapOutboundOut(frame), promise: nil)
- }
- }
- private func schedulePing(in delay: TimeAmount, timeout: TimeAmount) {
- guard delay != .nanoseconds(.max) else {
- return
- }
- self.scheduledPing = self.context?.eventLoop.scheduleRepeatedTask(
- initialDelay: delay,
- delay: delay
- ) { _ in
- self.handlePingAction(self.pingHandler.pingFired())
- // `timeout` is less than `interval`, guaranteeing that the close task
- // will be fired before a new ping is triggered.
- assert(timeout < delay, "`timeout` must be less than `interval`")
- self.scheduleClose(in: timeout)
- }
- }
- private func scheduleClose(in timeout: TimeAmount) {
- self.scheduledClose = self.context?.eventLoop.scheduleTask(in: timeout) {
- self.perform(operations: self.stateMachine.shutdownNow())
- }
- }
- private func idleTimeoutFired() {
- self.perform(operations: self.stateMachine.idleTimeoutTaskFired())
- }
- func handlerAdded(context: ChannelHandlerContext) {
- self.context = context
- }
- func handlerRemoved(context: ChannelHandlerContext) {
- self.context = nil
- }
- func userInboundEventTriggered(context: ChannelHandlerContext, event: Any) {
- if let created = event as? NIOHTTP2StreamCreatedEvent {
- self.perform(operations: self.stateMachine.streamCreated(withID: created.streamID))
- self.handlePingAction(self.pingHandler.streamCreated())
- context.fireUserInboundEventTriggered(event)
- } else if let closed = event as? StreamClosedEvent {
- self.perform(operations: self.stateMachine.streamClosed(withID: closed.streamID))
- self.handlePingAction(self.pingHandler.streamClosed())
- context.fireUserInboundEventTriggered(event)
- } else if event is ChannelShouldQuiesceEvent {
- self.perform(operations: self.stateMachine.initiateGracefulShutdown())
- // Swallow this event.
- } else {
- context.fireUserInboundEventTriggered(event)
- }
- }
- func errorCaught(context: ChannelHandlerContext, error: Error) {
- // No state machine action here.
- self.mode.connectionManager?.channelError(error)
- context.fireErrorCaught(error)
- }
- func channelActive(context: ChannelHandlerContext) {
- // No state machine action here.
- switch self.mode {
- case let .client(connectionManager, multiplexer):
- connectionManager.channelActive(channel: context.channel, multiplexer: multiplexer)
- case .server:
- ()
- }
- context.fireChannelActive()
- }
- func channelInactive(context: ChannelHandlerContext) {
- self.perform(operations: self.stateMachine.channelInactive())
- self.scheduledPing?.cancel()
- self.scheduledClose?.cancel()
- self.scheduledPing = nil
- self.scheduledClose = nil
- context.fireChannelInactive()
- }
- func channelRead(context: ChannelHandlerContext, data: NIOAny) {
- let frame = self.unwrapInboundIn(data)
- switch frame.payload {
- case .goAway:
- self.perform(operations: self.stateMachine.receiveGoAway())
- case let .settings(.settings(settings)):
- self.perform(operations: self.stateMachine.receiveSettings(settings))
- case let .ping(data, ack):
- self.handlePingAction(self.pingHandler.read(pingData: data, ack: ack))
- default:
- // We're not interested in other events.
- ()
- }
- context.fireChannelRead(data)
- }
- }
- extension HTTP2SettingsParameter {
- internal var loggingMetadataKey: String {
- switch self {
- case .headerTableSize:
- return "h2_settings_header_table_size"
- case .enablePush:
- return "h2_settings_enable_push"
- case .maxConcurrentStreams:
- return "h2_settings_max_concurrent_streams"
- case .initialWindowSize:
- return "h2_settings_initial_window_size"
- case .maxFrameSize:
- return "h2_settings_max_frame_size"
- case .maxHeaderListSize:
- return "h2_settings_max_header_list_size"
- case .enableConnectProtocol:
- return "h2_settings_enable_connect_protocol"
- default:
- return String(describing: self)
- }
- }
- }
|