// Copyright 2015 The Chromium Authors. All rights reserved. // Use of this source code is governed by a BSD-style license that can be // found in the LICENSE file. import 'dart:async'; import 'dart:convert'; import 'package:meta/meta.dart'; import 'package:stream_channel/stream_channel.dart'; import 'package:test/src/backend/runtime.dart'; // ignore: implementation_imports import 'package:test/src/backend/suite_platform.dart'; // ignore: implementation_imports import 'package:test/src/runner/plugin/platform.dart'; // ignore: implementation_imports import 'package:test/src/runner/plugin/hack_register_platform.dart' as hack; // ignore: implementation_imports import '../artifacts.dart'; import '../base/common.dart'; import '../base/file_system.dart'; import '../base/io.dart'; import '../base/process_manager.dart'; import '../compile.dart'; import '../dart/package_map.dart'; import '../globals.dart'; import 'watcher.dart'; /// The timeout we give the test process to connect to the test harness /// once the process has entered its main method. const Duration _kTestStartupTimeout = Duration(minutes: 1); /// The timeout we give the test process to start executing Dart code. When the /// CPU is under severe load, this can take a while, but it's not indicative of /// any problem with Flutter, so we give it a large timeout. const Duration _kTestProcessTimeout = Duration(minutes: 5); /// Message logged by the test process to signal that its main method has begun /// execution. /// /// The test harness responds by starting the [_kTestStartupTimeout] countdown. /// The CPU may be throttled, which can cause a long delay in between when the /// process is spawned and when dart code execution begins; we don't want to /// hold that against the test. const String _kStartTimeoutTimerMessage = 'sky_shell test process has entered main method'; /// The name of the test configuration file that will be discovered by the /// test harness if it exists in the project directory hierarchy. const String _kTestConfigFileName = 'flutter_test_config.dart'; /// The name of the file that signals the root of the project and that will /// cause the test harness to stop scanning for configuration files. const String _kProjectRootSentinel = 'pubspec.yaml'; /// The address at which our WebSocket server resides and at which the sky_shell /// processes will host the Observatory server. final Map<InternetAddressType, InternetAddress> _kHosts = <InternetAddressType, InternetAddress>{ InternetAddressType.IPv4: InternetAddress.loopbackIPv4, InternetAddressType.IPv6: InternetAddress.loopbackIPv6, }; /// Configure the `test` package to work with Flutter. /// /// On systems where each [_FlutterPlatform] is only used to run one test suite /// (that is, one Dart file with a `*_test.dart` file name and a single `void /// main()`), you can set an observatory port explicitly. void installHook({ @required String shellPath, TestWatcher watcher, bool enableObservatory = false, bool machine = false, bool startPaused = false, bool previewDart2 = false, int port = 0, String precompiledDillPath, bool trackWidgetCreation = false, bool updateGoldens = false, int observatoryPort, InternetAddressType serverType = InternetAddressType.IPv4, }) { assert(!enableObservatory || (!startPaused && observatoryPort == null)); hack.registerPlatformPlugin( <Runtime>[Runtime.vm], () => new _FlutterPlatform( shellPath: shellPath, watcher: watcher, machine: machine, enableObservatory: enableObservatory, startPaused: startPaused, explicitObservatoryPort: observatoryPort, host: _kHosts[serverType], previewDart2: previewDart2, port: port, precompiledDillPath: precompiledDillPath, trackWidgetCreation: trackWidgetCreation, updateGoldens: updateGoldens, ), ); } /// Generates the bootstrap entry point script that will be used to launch an /// individual test file. /// /// The [testUrl] argument specifies the path to the test file that is being /// launched. /// /// The [host] argument specifies the address at which the test harness is /// running. /// /// If [testConfigFile] is specified, it must follow the conventions of test /// configuration files as outlined in the [flutter_test] library. By default, /// the test file will be launched directly. /// /// The [updateGoldens] argument will set the [autoUpdateGoldens] global /// variable in the [flutter_test] package before invoking the test. String generateTestBootstrap({ @required Uri testUrl, @required InternetAddress host, File testConfigFile, bool updateGoldens = false, }) { assert(testUrl != null); assert(host != null); assert(updateGoldens != null); final String websocketUrl = host.type == InternetAddressType.IPv4 ? 'ws://${host.address}' : 'ws://[${host.address}]'; final String encodedWebsocketUrl = Uri.encodeComponent(websocketUrl); final StringBuffer buffer = new StringBuffer(); buffer.write(''' import 'dart:convert'; import 'dart:io'; // ignore: dart_io_import // We import this library first in order to trigger an import error for // package:test (rather than package:stream_channel) when the developer forgets // to add a dependency on package:test. import 'package:test/src/runner/plugin/remote_platform_helpers.dart'; import 'package:flutter_test/flutter_test.dart'; import 'package:stream_channel/stream_channel.dart'; import 'package:test/src/runner/vm/catch_isolate_errors.dart'; import '$testUrl' as test; ''' ); if (testConfigFile != null) { buffer.write(''' import '${new Uri.file(testConfigFile.path)}' as test_config; ''' ); } buffer.write(''' void main() { print('$_kStartTimeoutTimerMessage'); String serverPort = Platform.environment['SERVER_PORT']; String server = Uri.decodeComponent('$encodedWebsocketUrl:\$serverPort'); StreamChannel channel = serializeSuite(() { catchIsolateErrors(); goldenFileComparator = new LocalFileComparator(Uri.parse('$testUrl')); autoUpdateGoldenFiles = $updateGoldens; ''' ); if (testConfigFile != null) { buffer.write(''' return () => test_config.main(test.main); '''); } else { buffer.write(''' return test.main; '''); } buffer.write(''' }); WebSocket.connect(server).then((WebSocket socket) { socket.map((dynamic x) { assert(x is String); return json.decode(x); }).pipe(channel.sink); socket.addStream(channel.stream.map(json.encode)); }); } ''' ); return buffer.toString(); } enum _InitialResult { crashed, timedOut, connected } enum _TestResult { crashed, harnessBailed, testBailed } typedef Future<Null> _Finalizer(); class _CompilationRequest { String path; Completer<String> result; _CompilationRequest(this.path, this.result); } // This class is a wrapper around compiler that allows multiple isolates to // enqueue compilation requests, but ensures only one compilation at a time. class _Compiler { _Compiler(bool trackWidgetCreation) { // Compiler maintains and updates single incremental dill file. // Incremental compilation requests done for each test copy that file away // for independent execution. final Directory outputDillDirectory = fs.systemTempDirectory .createTempSync('flutter_test_compiler.'); final File outputDill = outputDillDirectory.childFile('output.dill'); printTrace('Compiler will use the following file as its incremental dill file: ${outputDill.path}'); bool suppressOutput = false; void reportCompilerMessage(String message) { if (suppressOutput) return; if (message.startsWith('compiler message: Error: Could not resolve the package \'test\'')) { printTrace(message); printError('\n\nFailed to load test harness. Are you missing a dependency on flutter_test?\n'); suppressOutput = true; return; } printError('$message'); } ResidentCompiler createCompiler() { return new ResidentCompiler( artifacts.getArtifactPath(Artifact.flutterPatchedSdkPath), packagesPath: PackageMap.globalPackagesPath, trackWidgetCreation: trackWidgetCreation, compilerMessageConsumer: reportCompilerMessage, ); } printTrace('Listening to compiler controller...'); compilerController.stream.listen((_CompilationRequest request) async { final bool isEmpty = compilationQueue.isEmpty; compilationQueue.add(request); // Only trigger processing if queue was empty - i.e. no other requests // are currently being processed. This effectively enforces "one // compilation request at a time". if (isEmpty) { while (compilationQueue.isNotEmpty) { final _CompilationRequest request = compilationQueue.first; printTrace('Compiling ${request.path}'); final Stopwatch compilerTime = new Stopwatch()..start(); compiler ??= createCompiler(); suppressOutput = false; final CompilerOutput compilerOutput = await handleTimeout<CompilerOutput>( compiler.recompile( request.path, <String>[request.path], outputPath: outputDill.path), request.path); final String outputPath = compilerOutput?.outputFilename; // In case compiler didn't produce output or reported compilation // errors, pass [null] upwards to the consumer and shutdown the // compiler to avoid reusing compiler that might have gotten into // a weird state. if (outputPath == null || compilerOutput.errorCount > 0) { request.result.complete(null); await _shutdown(); } else { final File kernelReadyToRun = await fs.file(outputPath).copy('${request.path}.dill'); request.result.complete(kernelReadyToRun.path); compiler.accept(); compiler.reset(); } printTrace('Compiling ${request.path} took ${compilerTime.elapsedMilliseconds}ms'); // Only remove now when we finished processing the element compilationQueue.removeAt(0); } } }, onDone: () { printTrace('Deleting ${outputDillDirectory.path}...'); outputDillDirectory.deleteSync(recursive: true); }); } final StreamController<_CompilationRequest> compilerController = new StreamController<_CompilationRequest>(); final List<_CompilationRequest> compilationQueue = <_CompilationRequest>[]; ResidentCompiler compiler; Future<String> compile(String mainDart) { final Completer<String> completer = new Completer<String>(); compilerController.add(new _CompilationRequest(mainDart, completer)); return handleTimeout<String>(completer.future, mainDart); } Future<void> _shutdown() async { // Check for null in case this instance is shut down before the // lazily-created compiler has been created. if (compiler != null) { await compiler.shutdown(); compiler = null; } } Future<void> dispose() async { await _shutdown(); await compilerController.close(); } static Future<T> handleTimeout<T>(Future<T> value, String path) { return value.timeout(const Duration(minutes: 5), onTimeout: () { printError('Compilation of $path timed out after 5 minutes.'); return null; }); } } class _FlutterPlatform extends PlatformPlugin { _FlutterPlatform({ @required this.shellPath, this.watcher, this.enableObservatory, this.machine, this.startPaused, this.explicitObservatoryPort, this.host, this.previewDart2, this.port, this.precompiledDillPath, this.trackWidgetCreation, this.updateGoldens, }) : assert(shellPath != null); final String shellPath; final TestWatcher watcher; final bool enableObservatory; final bool machine; final bool startPaused; final int explicitObservatoryPort; final InternetAddress host; final bool previewDart2; final int port; final String precompiledDillPath; final bool trackWidgetCreation; final bool updateGoldens; Directory fontsDirectory; _Compiler compiler; // Each time loadChannel() is called, we spin up a local WebSocket server, // then spin up the engine in a subprocess. We pass the engine a Dart file // that connects to our WebSocket server, then we proxy JSON messages from // the test harness to the engine and back again. If at any time the engine // crashes, we inject an error into that stream. When the process closes, // we clean everything up. int _testCount = 0; @override StreamChannel<dynamic> loadChannel(String testPath, SuitePlatform platform) { if (_testCount > 0) { // Fail if there will be a port conflict. if (explicitObservatoryPort != null) throwToolExit('installHook() was called with an observatory port or debugger mode enabled, but then more than one test suite was run.'); // Fail if we're passing in a precompiled entry-point. if (precompiledDillPath != null) throwToolExit('installHook() was called with a precompiled test entry-point, but then more than one test suite was run.'); } final int ourTestCount = _testCount; _testCount += 1; final StreamController<dynamic> localController = new StreamController<dynamic>(); final StreamController<dynamic> remoteController = new StreamController<dynamic>(); final Completer<_AsyncError> testCompleteCompleter = new Completer<_AsyncError>(); final _FlutterPlatformStreamSinkWrapper<dynamic> remoteSink = new _FlutterPlatformStreamSinkWrapper<dynamic>( remoteController.sink, testCompleteCompleter.future, ); final StreamChannel<dynamic> localChannel = new StreamChannel<dynamic>.withGuarantees( remoteController.stream, localController.sink, ); final StreamChannel<dynamic> remoteChannel = new StreamChannel<dynamic>.withGuarantees( localController.stream, remoteSink, ); testCompleteCompleter.complete(_startTest(testPath, localChannel, ourTestCount)); return remoteChannel; } Future<_AsyncError> _startTest( String testPath, StreamChannel<dynamic> controller, int ourTestCount, ) async { printTrace('test $ourTestCount: starting test $testPath'); _AsyncError outOfBandError; // error that we couldn't send to the harness that we need to send via our future final List<_Finalizer> finalizers = <_Finalizer>[]; // Will be run in reverse order. bool subprocessActive = false; bool controllerSinkClosed = false; try { // Callback can't throw since it's just setting a variable. controller.sink.done.whenComplete(() { controllerSinkClosed = true; }); // ignore: unawaited_futures // Prepare our WebSocket server to talk to the engine subproces. final HttpServer server = await HttpServer.bind(host, port); finalizers.add(() async { printTrace('test $ourTestCount: shutting down test harness socket server'); await server.close(force: true); }); final Completer<WebSocket> webSocket = new Completer<WebSocket>(); server.listen( (HttpRequest request) { if (!webSocket.isCompleted) webSocket.complete(WebSocketTransformer.upgrade(request)); }, onError: (dynamic error, dynamic stack) { // If you reach here, it's unlikely we're going to be able to really handle this well. printTrace('test $ourTestCount: test harness socket server experienced an unexpected error: $error'); if (!controllerSinkClosed) { controller.sink.addError(error, stack); controller.sink.close(); } else { printError('unexpected error from test harness socket server: $error'); } }, cancelOnError: true, ); printTrace('test $ourTestCount: starting shell process${previewDart2? " in preview-dart-2 mode":""}'); // [precompiledDillPath] can be set only if [previewDart2] is [true]. assert(precompiledDillPath == null || previewDart2); // If a kernel file is given, then use that to launch the test. // Otherwise create a "listener" dart that invokes actual test. String mainDart = precompiledDillPath != null ? precompiledDillPath : _createListenerDart(finalizers, ourTestCount, testPath, server); if (previewDart2 && precompiledDillPath == null) { // Lazily instantiate compiler so it is built only if it is actually used. compiler ??= new _Compiler(trackWidgetCreation); mainDart = await compiler.compile(mainDart); if (mainDart == null) { controller.sink.addError(_getErrorMessage('Compilation failed', testPath, shellPath)); return null; } } final Process process = await _startProcess( shellPath, mainDart, packages: PackageMap.globalPackagesPath, enableObservatory: enableObservatory, startPaused: startPaused, bundlePath: _getBundlePath(finalizers, ourTestCount), observatoryPort: explicitObservatoryPort, serverPort: server.port, ); subprocessActive = true; finalizers.add(() async { if (subprocessActive) { printTrace('test $ourTestCount: ensuring end-of-process for shell'); process.kill(); final int exitCode = await process.exitCode; subprocessActive = false; if (!controllerSinkClosed && exitCode != -15) { // ProcessSignal.SIGTERM // We expect SIGTERM (15) because we tried to terminate it. // It's negative because signals are returned as negative exit codes. final String message = _getErrorMessage(_getExitCodeMessage(exitCode, 'after tests finished'), testPath, shellPath); controller.sink.addError(message); } } }); final Completer<void> timeout = new Completer<void>(); final Completer<void> gotProcessObservatoryUri = new Completer<void>(); if (!enableObservatory) gotProcessObservatoryUri.complete(); // Pipe stdout and stderr from the subprocess to our printStatus console. // We also keep track of what observatory port the engine used, if any. Uri processObservatoryUri; _pipeStandardStreamsToConsole( process, reportObservatoryUri: (Uri detectedUri) { assert(processObservatoryUri == null); assert(explicitObservatoryPort == null || explicitObservatoryPort == detectedUri.port); if (startPaused && !machine) { printStatus('The test process has been started.'); printStatus('You can now connect to it using observatory. To connect, load the following Web site in your browser:'); printStatus(' $detectedUri'); printStatus('You should first set appropriate breakpoints, then resume the test in the debugger.'); } else { printTrace('test $ourTestCount: using observatory uri $detectedUri from pid ${process.pid}'); } processObservatoryUri = detectedUri; gotProcessObservatoryUri.complete(); watcher?.handleStartedProcess(new ProcessEvent(ourTestCount, process, processObservatoryUri)); }, startTimeoutTimer: () { new Future<_InitialResult>.delayed(_kTestStartupTimeout).then((_) => timeout.complete()); }, ); // At this point, three things can happen next: // The engine could crash, in which case process.exitCode will complete. // The engine could connect to us, in which case webSocket.future will complete. // The local test harness could get bored of us. printTrace('test $ourTestCount: awaiting initial result for pid ${process.pid}'); final _InitialResult initialResult = await Future.any(<Future<_InitialResult>>[ process.exitCode.then<_InitialResult>((int exitCode) => _InitialResult.crashed), timeout.future.then<_InitialResult>((void value) => _InitialResult.timedOut), new Future<_InitialResult>.delayed(_kTestProcessTimeout, () => _InitialResult.timedOut), gotProcessObservatoryUri.future.then<_InitialResult>((void value) { return webSocket.future.then<_InitialResult>( (WebSocket webSocket) => _InitialResult.connected, ); }), ]); switch (initialResult) { case _InitialResult.crashed: printTrace('test $ourTestCount: process with pid ${process.pid} crashed before connecting to test harness'); final int exitCode = await process.exitCode; subprocessActive = false; final String message = _getErrorMessage(_getExitCodeMessage(exitCode, 'before connecting to test harness'), testPath, shellPath); controller.sink.addError(message); // Awaited for with 'sink.done' below. controller.sink.close(); // ignore: unawaited_futures printTrace('test $ourTestCount: waiting for controller sink to close'); await controller.sink.done; await watcher?.handleTestCrashed(new ProcessEvent(ourTestCount, process)); break; case _InitialResult.timedOut: // Could happen either if the process takes a long time starting // (_kTestProcessTimeout), or if once Dart code starts running, it takes a // long time to open the WebSocket connection (_kTestStartupTimeout). printTrace('test $ourTestCount: timed out waiting for process with pid ${process.pid} to connect to test harness'); final String message = _getErrorMessage('Test never connected to test harness.', testPath, shellPath); controller.sink.addError(message); // Awaited for with 'sink.done' below. controller.sink.close(); // ignore: unawaited_futures printTrace('test $ourTestCount: waiting for controller sink to close'); await controller.sink.done; await watcher?.handleTestTimedOut(new ProcessEvent(ourTestCount, process)); break; case _InitialResult.connected: printTrace('test $ourTestCount: process with pid ${process.pid} connected to test harness'); final WebSocket testSocket = await webSocket.future; final Completer<void> harnessDone = new Completer<void>(); final StreamSubscription<dynamic> harnessToTest = controller.stream.listen( (dynamic event) { testSocket.add(json.encode(event)); }, onDone: harnessDone.complete, onError: (dynamic error, dynamic stack) { // If you reach here, it's unlikely we're going to be able to really handle this well. printError('test harness controller stream experienced an unexpected error\ntest: $testPath\nerror: $error'); if (!controllerSinkClosed) { controller.sink.addError(error, stack); controller.sink.close(); } else { printError('unexpected error from test harness controller stream: $error'); } }, cancelOnError: true, ); final Completer<void> testDone = new Completer<void>(); final StreamSubscription<dynamic> testToHarness = testSocket.listen( (dynamic encodedEvent) { assert(encodedEvent is String); // we shouldn't ever get binary messages controller.sink.add(json.decode(encodedEvent)); }, onDone: testDone.complete, onError: (dynamic error, dynamic stack) { // If you reach here, it's unlikely we're going to be able to really handle this well. printError('test socket stream experienced an unexpected error\ntest: $testPath\nerror: $error'); if (!controllerSinkClosed) { controller.sink.addError(error, stack); controller.sink.close(); } else { printError('unexpected error from test socket stream: $error'); } }, cancelOnError: true, ); printTrace('test $ourTestCount: awaiting test result for pid ${process.pid}'); final _TestResult testResult = await Future.any(<Future<_TestResult>>[ process.exitCode.then<_TestResult>((int exitCode) { return _TestResult.crashed; }), harnessDone.future.then<_TestResult>((void value) { return _TestResult.harnessBailed; }), testDone.future.then<_TestResult>((void value) { return _TestResult.testBailed; }), ]); await Future.wait(<Future<void>>[ harnessToTest.cancel(), testToHarness.cancel(), ]); switch (testResult) { case _TestResult.crashed: printTrace('test $ourTestCount: process with pid ${process.pid} crashed'); final int exitCode = await process.exitCode; subprocessActive = false; final String message = _getErrorMessage(_getExitCodeMessage(exitCode, 'before test harness closed its WebSocket'), testPath, shellPath); controller.sink.addError(message); // Awaited for with 'sink.done' below. controller.sink.close(); // ignore: unawaited_futures printTrace('test $ourTestCount: waiting for controller sink to close'); await controller.sink.done; break; case _TestResult.harnessBailed: case _TestResult.testBailed: if (testResult == _TestResult.harnessBailed) { printTrace('test $ourTestCount: process with pid ${process.pid} no longer needed by test harness'); } else { assert(testResult == _TestResult.testBailed); printTrace('test $ourTestCount: process with pid ${process.pid} no longer needs test harness'); } await watcher?.handleFinishedTest(new ProcessEvent(ourTestCount, process, processObservatoryUri)); break; } break; } } catch (error, stack) { printTrace('test $ourTestCount: error caught during test; ${controllerSinkClosed ? "reporting to console" : "sending to test framework"}'); if (!controllerSinkClosed) { controller.sink.addError(error, stack); } else { printError('unhandled error during test:\n$testPath\n$error\n$stack'); outOfBandError ??= new _AsyncError(error, stack); } } finally { printTrace('test $ourTestCount: cleaning up...'); // Finalizers are treated like a stack; run them in reverse order. for (_Finalizer finalizer in finalizers.reversed) { try { await finalizer(); } catch (error, stack) { printTrace('test $ourTestCount: error while cleaning up; ${controllerSinkClosed ? "reporting to console" : "sending to test framework"}'); if (!controllerSinkClosed) { controller.sink.addError(error, stack); } else { printError('unhandled error during finalization of test:\n$testPath\n$error\n$stack'); outOfBandError ??= new _AsyncError(error, stack); } } } if (!controllerSinkClosed) { // Waiting below with await. controller.sink.close(); // ignore: unawaited_futures printTrace('test $ourTestCount: waiting for controller sink to close'); await controller.sink.done; } } assert(!subprocessActive); assert(controllerSinkClosed); if (outOfBandError != null) { printTrace('test $ourTestCount: finished with out-of-band failure'); } else { printTrace('test $ourTestCount: finished'); } return outOfBandError; } String _createListenerDart(List<_Finalizer> finalizers, int ourTestCount, String testPath, HttpServer server) { // Prepare a temporary directory to store the Dart file that will talk to us. final Directory tempDir = fs.systemTempDirectory .createTempSync('flutter_test_listener.'); finalizers.add(() async { printTrace('test $ourTestCount: deleting temporary directory'); tempDir.deleteSync(recursive: true); }); // Prepare the Dart file that will talk to us and start the test. final File listenerFile = fs.file('${tempDir.path}/listener.dart'); listenerFile.createSync(); listenerFile.writeAsStringSync(_generateTestMain( testUrl: fs.path.toUri(fs.path.absolute(testPath)), )); return listenerFile.path; } String _getBundlePath(List<_Finalizer> finalizers, int ourTestCount) { if (!previewDart2) { return null; } if (precompiledDillPath != null) { return artifacts.getArtifactPath(Artifact.flutterPatchedSdkPath); } // bundlePath needs to point to a folder with `platform.dill` file. final Directory tempBundleDirectory = fs.systemTempDirectory .createTempSync('flutter_test_bundle.'); finalizers.add(() async { printTrace( 'test $ourTestCount: deleting temporary bundle directory'); tempBundleDirectory.deleteSync(recursive: true); }); // copy 'vm_platform_strong.dill' into 'platform_strong.dill' final File vmPlatformStrongDill = fs.file( artifacts.getArtifactPath(Artifact.platformKernelDill), ); printTrace('Copying platform_strong.dill file from ${vmPlatformStrongDill.path}'); final File platformDill = vmPlatformStrongDill.copySync( tempBundleDirectory .childFile('platform_strong.dill') .path, ); if (!platformDill.existsSync()) { printError('unexpected error copying platform kernel file'); } return tempBundleDirectory.path; } String _generateTestMain({ Uri testUrl, }) { assert(testUrl.scheme == 'file'); File testConfigFile; Directory directory = fs.file(testUrl).parent; while (directory.path != directory.parent.path) { final File configFile = directory.childFile(_kTestConfigFileName); if (configFile.existsSync()) { printTrace('Discovered $_kTestConfigFileName in ${directory.path}'); testConfigFile = configFile; break; } if (directory.childFile(_kProjectRootSentinel).existsSync()) { printTrace('Stopping scan for $_kTestConfigFileName; ' 'found project root at ${directory.path}'); break; } directory = directory.parent; } return generateTestBootstrap( testUrl: testUrl, testConfigFile: testConfigFile, host: host, updateGoldens: updateGoldens, ); } File _cachedFontConfig; @override Future<dynamic> close() async { if (compiler != null) { await compiler.dispose(); compiler = null; } if (fontsDirectory != null) { printTrace('Deleting ${fontsDirectory.path}...'); fontsDirectory.deleteSync(recursive: true); fontsDirectory = null; } } /// Returns a Fontconfig config file that limits font fallback to the /// artifact cache directory. File get _fontConfigFile { if (_cachedFontConfig != null) return _cachedFontConfig; final StringBuffer sb = new StringBuffer(); sb.writeln('<fontconfig>'); sb.writeln(' <dir>${cache.getCacheArtifacts().path}</dir>'); sb.writeln(' <cachedir>/var/cache/fontconfig</cachedir>'); sb.writeln('</fontconfig>'); if (fontsDirectory == null) { fontsDirectory = fs.systemTempDirectory.createTempSync('flutter_test_fonts.'); printTrace('Using this directory for fonts configuration: ${fontsDirectory.path}'); } _cachedFontConfig = fs.file('${fontsDirectory.path}/fonts.conf'); _cachedFontConfig.createSync(); _cachedFontConfig.writeAsStringSync(sb.toString()); return _cachedFontConfig; } Future<Process> _startProcess( String executable, String testPath, { String packages, String bundlePath, bool enableObservatory = false, bool startPaused = false, int observatoryPort, int serverPort, }) { assert(executable != null); // Please provide the path to the shell in the SKY_SHELL environment variable. assert(!startPaused || enableObservatory); final List<String> command = <String>[executable]; if (enableObservatory) { // Some systems drive the _FlutterPlatform class in an unusual way, where // only one test file is processed at a time, and the operating // environment hands out specific ports ahead of time in a cooperative // manner, where we're only allowed to open ports that were given to us in // advance like this. For those esoteric systems, we have this feature // whereby you can create _FlutterPlatform with a pair of ports. // // I mention this only so that you won't be tempted, as I was, to apply // the obvious simplification to this code and remove this entire feature. if (observatoryPort != null) command.add('--observatory-port=$observatoryPort'); if (startPaused) command.add('--start-paused'); } else { command.add('--disable-observatory'); } if (host.type == InternetAddressType.IPv6) command.add('--ipv6'); if (bundlePath != null) { command.add('--flutter-assets-dir=$bundlePath'); } command.add('--enable-checked-mode'); command.addAll(<String>[ '--enable-software-rendering', '--skia-deterministic-rendering', '--enable-dart-profiling', '--non-interactive', '--use-test-fonts', '--packages=$packages', testPath, ]); printTrace(command.join(' ')); final Map<String, String> environment = <String, String>{ 'FLUTTER_TEST': 'true', 'FONTCONFIG_FILE': _fontConfigFile.path, 'SERVER_PORT': serverPort.toString(), }; return processManager.start(command, environment: environment); } void _pipeStandardStreamsToConsole( Process process, { void startTimeoutTimer(), void reportObservatoryUri(Uri uri), }) { const String observatoryString = 'Observatory listening on '; for (Stream<List<int>> stream in <Stream<List<int>>>[process.stderr, process.stdout]) { stream.transform(utf8.decoder) .transform(const LineSplitter()) .listen( (String line) { if (line == _kStartTimeoutTimerMessage) { if (startTimeoutTimer != null) startTimeoutTimer(); } else if (line.startsWith('error: Unable to read Dart source \'package:test/')) { printTrace('Shell: $line'); printError('\n\nFailed to load test harness. Are you missing a dependency on flutter_test?\n'); } else if (line.startsWith(observatoryString)) { printTrace('Shell: $line'); try { final Uri uri = Uri.parse(line.substring(observatoryString.length)); if (reportObservatoryUri != null) reportObservatoryUri(uri); } catch (error) { printError('Could not parse shell observatory port message: $error'); } } else if (line != null) { printStatus('Shell: $line'); } }, onError: (dynamic error) { printError('shell console stream for process pid ${process.pid} experienced an unexpected error: $error'); }, cancelOnError: true, ); } } String _getErrorMessage(String what, String testPath, String shellPath) { return '$what\nTest: $testPath\nShell: $shellPath\n\n'; } String _getExitCodeMessage(int exitCode, String when) { switch (exitCode) { case 1: return 'Shell subprocess cleanly reported an error $when. Check the logs above for an error message.'; case 0: return 'Shell subprocess ended cleanly $when. Did main() call exit()?'; case -0x0f: // ProcessSignal.SIGTERM return 'Shell subprocess crashed with SIGTERM ($exitCode) $when.'; case -0x0b: // ProcessSignal.SIGSEGV return 'Shell subprocess crashed with segmentation fault $when.'; case -0x06: // ProcessSignal.SIGABRT return 'Shell subprocess crashed with SIGABRT ($exitCode) $when.'; case -0x02: // ProcessSignal.SIGINT return 'Shell subprocess terminated by ^C (SIGINT, $exitCode) $when.'; default: return 'Shell subprocess crashed with unexpected exit code $exitCode $when.'; } } } // The [_shellProcessClosed] future can't have errors thrown on it because it // crosses zones (it's fed in a zone created by the test package, but listened // to by a parent zone, the same zone that calls [close] below). // // This is because Dart won't let errors that were fed into a Future in one zone // propagate to listeners in another zone. (Specifically, the zone in which the // future was completed with the error, and the zone in which the listener was // registered, are what matters.) // // Because of this, the [_shellProcessClosed] future takes an [_AsyncError] // object as a result. If it's null, it's as if it had completed correctly; if // it's non-null, it contains the error and stack trace of the actual error, as // if it had completed with that error. class _FlutterPlatformStreamSinkWrapper<S> implements StreamSink<S> { _FlutterPlatformStreamSinkWrapper(this._parent, this._shellProcessClosed); final StreamSink<S> _parent; final Future<_AsyncError> _shellProcessClosed; @override Future<void> get done => _done.future; final Completer<void> _done = new Completer<void>(); @override Future<dynamic> close() { Future.wait<dynamic>(<Future<dynamic>>[ _parent.close(), _shellProcessClosed, ]).then<void>( (List<dynamic> futureResults) { assert(futureResults.length == 2); assert(futureResults.first == null); if (futureResults.last is _AsyncError) { _done.completeError(futureResults.last.error, futureResults.last.stack); } else { assert(futureResults.last == null); _done.complete(); } }, onError: _done.completeError, ); return done; } @override void add(S event) => _parent.add(event); @override void addError(dynamic errorEvent, [ StackTrace stackTrace ]) => _parent.addError(errorEvent, stackTrace); @override Future<dynamic> addStream(Stream<S> stream) => _parent.addStream(stream); } @immutable class _AsyncError { const _AsyncError(this.error, this.stack); final dynamic error; final StackTrace stack; }