Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- absolute - Variable in class org.apache.maven.plugin.surefire.booterclient.JarManifestForkConfiguration.ClasspathElementUri
- absolute(String) - Static method in class org.apache.maven.plugin.surefire.booterclient.JarManifestForkConfiguration.ClasspathElementUri
- AbstractClasspathForkConfiguration - Class in org.apache.maven.plugin.surefire.booterclient
- AbstractClasspathForkConfiguration(Classpath, File, String, File, Properties, String, Map<String, String>, String[], boolean, int, boolean, Platform, ConsoleLogger, ForkNodeFactory) - Constructor for class org.apache.maven.plugin.surefire.booterclient.AbstractClasspathForkConfiguration
- AbstractCommandReader - Class in org.apache.maven.plugin.surefire.booterclient.lazytestprovider
-
Stream reader returns bytes which are finally sent to the forked jvm std-input-stream.
- AbstractCommandReader() - Constructor for class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.AbstractCommandReader
- AbstractConsoleEvent - Class in org.apache.maven.surefire.api.event
-
The base class of an event.
- AbstractConsoleEvent(ForkedProcessEventType, String) - Constructor for class org.apache.maven.surefire.api.event.AbstractConsoleEvent
- AbstractDirectConfigurator - Class in org.apache.maven.surefire.testng.conf
-
Configurator that relies on reflection to set parameters in TestNG
- AbstractDirectConfigurator() - Constructor for class org.apache.maven.surefire.testng.conf.AbstractDirectConfigurator
- AbstractDirectConfigurator.Setter - Class in org.apache.maven.surefire.testng.conf
-
Describes a property setter by method name and parameter class
- AbstractMasterProcessChannelProcessorFactory - Class in org.apache.maven.surefire.booter.spi
-
Default implementation of
MasterProcessChannelProcessorFactory
. - AbstractMasterProcessChannelProcessorFactory() - Constructor for class org.apache.maven.surefire.booter.spi.AbstractMasterProcessChannelProcessorFactory
- AbstractNoninterruptibleReadableChannel - Class in org.apache.maven.surefire.api.util.internal
-
The channel used for reads which cannot be implicitly closed after the operational Thread is
interrupted
. - AbstractNoninterruptibleReadableChannel() - Constructor for class org.apache.maven.surefire.api.util.internal.AbstractNoninterruptibleReadableChannel
- AbstractNoninterruptibleWritableChannel - Class in org.apache.maven.surefire.api.util.internal
-
The channel used for writes which cannot be implicitly closed after the operational Thread is
interrupted
. - AbstractNoninterruptibleWritableChannel() - Constructor for class org.apache.maven.surefire.api.util.internal.AbstractNoninterruptibleWritableChannel
- AbstractPathConfiguration - Class in org.apache.maven.surefire.booter
- AbstractPathConfiguration(Classpath, boolean, boolean) - Constructor for class org.apache.maven.surefire.booter.AbstractPathConfiguration
- AbstractProvider - Class in org.apache.maven.surefire.api.provider
-
A provider base class that all providers should extend to shield themselves from interface changes
- AbstractProvider() - Constructor for class org.apache.maven.surefire.api.provider.AbstractProvider
- AbstractStandardStreamEvent - Class in org.apache.maven.surefire.api.event
-
The base class of an event of standard streams.
- AbstractStandardStreamEvent(ForkedProcessEventType, RunMode, Long, String) - Constructor for class org.apache.maven.surefire.api.event.AbstractStandardStreamEvent
- AbstractStreamDecoder<M,
MT extends Enum<MT>, ST extends Enum<ST>> - Class in org.apache.maven.surefire.api.stream - AbstractStreamDecoder(ReadableByteChannel, ForkNodeArguments, Map<AbstractStreamDecoder.Segment, MT>) - Constructor for class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- AbstractStreamDecoder.BufferedStream - Class in org.apache.maven.surefire.api.stream
-
This class avoids locking which gains the performance of this decoder.
- AbstractStreamDecoder.MalformedFrameException - Exception in org.apache.maven.surefire.api.stream
- AbstractStreamDecoder.Memento - Class in org.apache.maven.surefire.api.stream
- AbstractStreamDecoder.Segment - Class in org.apache.maven.surefire.api.stream
- AbstractStreamDecoder.StreamReadStatus - Enum Class in org.apache.maven.surefire.api.stream
-
Underflow - could not completely read out al bytes in one call.
- AbstractStreamEncoder<E extends Enum<E>> - Class in org.apache.maven.surefire.api.stream
-
The base class of stream encoder.
- AbstractStreamEncoder(WritableByteChannel) - Constructor for class org.apache.maven.surefire.api.stream.AbstractStreamEncoder
- AbstractSurefireMojo - Class in org.apache.maven.plugin.surefire
-
Abstract base class for running tests using Surefire.
- AbstractSurefireMojo() - Constructor for class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- AbstractSurefireMojo.ClasspathCache - Class in org.apache.maven.plugin.surefire
- AbstractSurefireMojo.DynamicProviderInfo - Class in org.apache.maven.plugin.surefire
-
Provides the Provider information for manually configured providers.
- AbstractSurefireMojo.JUnit3ProviderInfo - Class in org.apache.maven.plugin.surefire
- AbstractSurefireMojo.JUnit4ProviderInfo - Class in org.apache.maven.plugin.surefire
- AbstractSurefireMojo.JUnitCoreProviderInfo - Class in org.apache.maven.plugin.surefire
- AbstractSurefireMojo.JUnitPlatformProviderInfo - Class in org.apache.maven.plugin.surefire
- AbstractSurefireMojo.PluginFailureReason - Enum Class in org.apache.maven.plugin.surefire
-
Determines whether the plugin should fail if no tests found to run.
- AbstractSurefireMojo.TestNgProviderInfo - Class in org.apache.maven.plugin.surefire
- AbstractTestControlEvent<T extends ReportEntry> - Class in org.apache.maven.surefire.api.event
-
The base class of an event of test control.
- AbstractTestControlEvent(ForkedProcessEventType, T) - Constructor for class org.apache.maven.surefire.api.event.AbstractTestControlEvent
- AbstractThreadPoolStrategy - Class in org.apache.maven.surefire.junitcore.pc
-
Abstract parallel scheduling strategy in private package.
- AbstractThreadPoolStrategy(ConsoleLogger, ExecutorService) - Constructor for class org.apache.maven.surefire.junitcore.pc.AbstractThreadPoolStrategy
- AbstractThreadPoolStrategy(ConsoleLogger, ExecutorService, Collection<Future<?>>) - Constructor for class org.apache.maven.surefire.junitcore.pc.AbstractThreadPoolStrategy
- accept(Class) - Method in class org.apache.maven.surefire.api.filter.NonAbstractClassFilter
- accept(Class) - Method in class org.apache.maven.surefire.api.filter.SpecificTestClassFilter
- accept(Class) - Method in interface org.apache.maven.surefire.api.util.ScannerFilter
-
Indicates if the class should be accepted by the directory scanner
- accept(Class) - Method in class org.apache.maven.surefire.common.junit3.JUnit3TestChecker
- accept(Class) - Method in class org.apache.maven.surefire.common.junit4.JUnit4TestChecker
- accept(Class) - Method in class org.apache.maven.surefire.common.junit48.JUnit48TestChecker
- accept(Class) - Method in class org.apache.maven.surefire.junit.PojoAndJUnit3Checker
- accept(Class) - Method in class org.apache.maven.surefire.junitplatform.TestPlanScannerFilter
- accept(String) - Method in class org.apache.maven.plugin.surefire.util.SpecificFileFilter
-
Deprecated.
- acknowledgeByeEventReceived() - Method in interface org.apache.maven.plugin.surefire.booterclient.lazytestprovider.NotifiableTestStream
- acknowledgeByeEventReceived() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream
- acknowledgeByeEventReceived() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder.CachableCommands
- acknowledgeByeEventReceived() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder.ImmediateCommands
- acknowledgeByeEventReceived() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestProvidingInputStream
- acknowledgedExit() - Method in class org.apache.maven.surefire.booter.ForkedBooter
- acquireNextTest() - Method in interface org.apache.maven.surefire.api.booter.MasterProcessChannelEncoder
-
The provider acquires a new test set to run.
- acquireNextTest() - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- AcquireNextTestListener() - Constructor for class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.AcquireNextTestListener
- acquireOnePermit(Semaphore) - Static method in class org.apache.maven.surefire.booter.ForkedBooter
- acquirePermit() - Method in interface org.apache.maven.surefire.junitcore.pc.Balancer
-
Acquires a permit from this balancer, blocking until one is available.
- acquirePermit() - Method in class org.apache.maven.surefire.junitcore.pc.NullBalancer
- acquirePermit() - Method in class org.apache.maven.surefire.junitcore.pc.ThreadResourcesBalancer
-
Acquires a permit from this balancer, blocking until one is available.
- activeThreads - Variable in class org.apache.maven.surefire.junitcore.pc.InvokerStrategy
- add(boolean) - Method in class org.apache.maven.plugin.surefire.booterclient.ChecksumCalculator
- add(double) - Method in class org.apache.maven.plugin.surefire.booterclient.ChecksumCalculator
- add(int) - Method in class org.apache.maven.plugin.surefire.booterclient.ChecksumCalculator
- add(File) - Method in class org.apache.maven.plugin.surefire.booterclient.ChecksumCalculator
- add(Boolean) - Method in class org.apache.maven.plugin.surefire.booterclient.ChecksumCalculator
- add(Object[]) - Method in class org.apache.maven.plugin.surefire.booterclient.ChecksumCalculator
- add(String) - Method in class org.apache.maven.plugin.surefire.booterclient.ChecksumCalculator
- add(List<?>) - Method in class org.apache.maven.plugin.surefire.booterclient.ChecksumCalculator
- add(Map<?, ?>) - Method in class org.apache.maven.plugin.surefire.booterclient.ChecksumCalculator
- add(Artifact) - Method in class org.apache.maven.plugin.surefire.booterclient.ChecksumCalculator
- add(ArtifactRepository) - Method in class org.apache.maven.plugin.surefire.booterclient.ChecksumCalculator
- add(RunEntryStatistics) - Method in class org.apache.maven.surefire.api.runorder.RunEntryStatisticsMap
- ADD_ERROR - Static variable in class org.apache.maven.surefire.junit.TestListenerInvocationHandler
- ADD_FAILURE - Static variable in class org.apache.maven.surefire.junit.TestListenerInvocationHandler
- ADD_LISTENER_METHOD - Static variable in class org.apache.maven.surefire.common.junit3.JUnit3Reflector
- addByeAckListener(CommandListener) - Method in class org.apache.maven.surefire.booter.CommandReader
- addClassPathElementUrl(String) - Method in class org.apache.maven.surefire.booter.Classpath
- addCloseable(Closeable) - Method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter.CloseableCloser
- addCommentElementTestCase(String, OutputStreamWriter, XMLWriter, OutputStream) - Static method in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- addedEnvironmentVariables - Variable in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.Commandline
- addEngineByApi(String, String, String, Map<String, Artifact>) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnitPlatformProviderInfo
- addEnvironment(String, String) - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.Commandline
- addException(Throwable) - Method in exception org.apache.maven.plugin.surefire.booterclient.output.MultipleFailureException
- addItem(RunEntryStatistics) - Method in class org.apache.maven.surefire.api.runorder.Priority
- additionalClasspathElements - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Additional elements to be appended to the classpath.
- additionalClasspathElements - Variable in class org.apache.maven.plugin.surefire.TestClassPath
- addList(List<?>, String) - Method in class org.apache.maven.plugin.surefire.SurefireProperties
- addList(List, String) - Method in class org.apache.maven.surefire.booter.PropertiesWrapper
- addListener(TestSetRunListener) - Method in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
- addListener(MasterProcessCommand, CommandListener) - Method in class org.apache.maven.surefire.booter.CommandReader
- addListener(RunListener) - Method in class org.apache.maven.surefire.common.junit4.Notifier
- addListenerMethod - Variable in class org.apache.maven.surefire.common.junit3.JUnit3Reflector
- addListeners(Collection<RunListener>) - Method in class org.apache.maven.surefire.common.junit4.Notifier
- addListeners(RunListener...) - Method in class org.apache.maven.surefire.common.junit4.Notifier
- addNext(T) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.QueueSynchronizer
- addNoopListener(CommandListener) - Method in class org.apache.maven.surefire.booter.CommandReader
- addOutputStreamElement(OutputStreamWriter, StatelessXmlReporter.EncodingOutputStream, XMLWriter, Utf8RecodingDeferredFileOutputStream, String) - Static method in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- addPluginSpecificChecksumItems(ChecksumCalculator) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- addPluginSpecificChecksumItems(ChecksumCalculator) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- addPluginSpecificChecksumItems(ChecksumCalculator) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- addPropIfNotNull(Map<String, String>, Map<String, String>, String) - Method in class org.apache.maven.surefire.testng.conf.AbstractDirectConfigurator
- addProviderProperties() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.DynamicProviderInfo
- addProviderProperties() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnit3ProviderInfo
- addProviderProperties() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnit4ProviderInfo
- addProviderProperties() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnitCoreProviderInfo
- addProviderProperties() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnitPlatformProviderInfo
- addProviderProperties() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.TestNgProviderInfo
- addProviderProperties() - Method in interface org.apache.maven.surefire.providerapi.ProviderInfo
- addSelector(XmlTest, XmlMethodSelector) - Static method in class org.apache.maven.surefire.testng.TestNGExecutor
- addShutdownListener(CommandListener) - Method in interface org.apache.maven.surefire.api.provider.CommandChainReader
- addShutdownListener(CommandListener) - Method in class org.apache.maven.surefire.booter.CommandReader
- addSkipNextTestsListener(CommandListener) - Method in interface org.apache.maven.surefire.api.provider.CommandChainReader
- addSkipNextTestsListener(CommandListener) - Method in class org.apache.maven.surefire.booter.CommandReader
- addSystemEnvironment() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.Commandline
- addTailNodeIfAbsent(Command) - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder
- addTest(PrioritizedTest) - Method in class org.apache.maven.surefire.api.runorder.ThreadedExecutionScheduler
- addTestMethod(TestMethod) - Method in class org.apache.maven.surefire.junitcore.TestSet
-
Deprecated.
- addTestMethodStats() - Method in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- addTo(Collection<String>) - Method in class org.apache.maven.surefire.booter.Classpath
- addURL(URL) - Method in class org.apache.maven.surefire.booter.IsolatedClassLoader
-
Deprecated.
- adjustLeaf(JUnitCoreParameters, Concurrency) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerUtil
- adjustPrecisionInLeaf(JUnitCoreParameters, Concurrency) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerUtil
- afterException(Throwable) - Method in class org.apache.maven.surefire.junitcore.JUnitCore
- afterException(Throwable) - Method in class org.apache.maven.surefire.junitcore.JUnitCoreWrapper.JUnitCore
- afterExecute() - Method in class org.apache.maven.surefire.junitcore.pc.Scheduler
- afterFinished() - Method in class org.apache.maven.surefire.junitcore.JUnitCore
- afterFinished() - Method in class org.apache.maven.surefire.junitcore.JUnitCoreWrapper.JUnitCore
- afterInvocation(IInvokedMethod, ITestResult) - Method in class org.apache.maven.surefire.testng.utils.FailFastNotifier
- afterRunQuietly() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputer
- aggregate(RunResult) - Method in class org.apache.maven.surefire.api.suite.RunResult
- aggregateCacheFromMultipleReruns(WrappedReportEntry, TestSetStats) - Method in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- aggregatedTest(String, Set<ResolvedTest>) - Static method in class org.apache.maven.surefire.api.testset.TestListResolver
- alignProviderVersions(Map<String, Artifact>) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnitPlatformProviderInfo
- aliveStreams - Variable in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder
- ALL - Enum constant in enum class org.apache.maven.surefire.booter.ProcessCheckerType
- allFailures - Variable in class org.apache.maven.surefire.common.junit4.JUnitTestFailureListener
- allFiltersMatchDescription(Collection<Filter>, Description) - Method in class org.apache.maven.surefire.common.junit48.CombinedCategoryFilter
- allGroups - Variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- allowEagerReading() - Method in class org.apache.maven.surefire.api.util.TestsToRun
- allowEagerReading() - Method in class org.apache.maven.surefire.booter.LazyTestsToRun
- allScheduled - Variable in class org.apache.maven.surefire.junitcore.TestSet
-
Deprecated.
- alphabetical() - Static method in class org.apache.maven.surefire.api.testset.RunOrderParameters
- ALPHABETICAL - Static variable in class org.apache.maven.surefire.api.util.RunOrder
- alwaysInclusiveQuietly(String) - Method in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.Prevents
ResolvedTest.match(String, String)
from throwing NPE in situations when inclusive returns true. - AMP_BYTES - Static variable in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter.ByteConstantsHolder
- and(TestListResolver) - Method in class org.apache.maven.surefire.api.testset.TestListResolver
- AndFilter - Class in org.apache.maven.surefire.common.junit48
- AndFilter(Filter...) - Constructor for class org.apache.maven.surefire.common.junit48.AndFilter
- annotationType() - Method in class org.apache.maven.surefire.common.junit4.JUnit4Reflector.IgnoredWithUserError
- anyFilterMatchesDescription(Collection<Filter>, Description) - Method in class org.apache.maven.surefire.common.junit48.CombinedCategoryFilter
- append(char) - Method in class org.apache.maven.surefire.api.report.ConsoleOutputCapture.ForwardingPrintStream
- append(CharSequence) - Method in class org.apache.maven.surefire.api.report.ConsoleOutputCapture.ForwardingPrintStream
- append(CharSequence, int, int) - Method in class org.apache.maven.surefire.api.report.ConsoleOutputCapture.ForwardingPrintStream
- append(DefaultScanResult) - Method in class org.apache.maven.surefire.api.util.DefaultScanResult
- appendObject(Object) - Method in class org.apache.maven.plugin.surefire.booterclient.ChecksumCalculator
- apply(Object) - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC.SuiteFilter
- apply(TestDescriptor) - Method in class org.apache.maven.surefire.junitplatform.TestMethodFilter
- applyFilter(ScannerFilter, ClassLoader) - Method in class org.apache.maven.surefire.api.util.DefaultScanResult
- applyFilter(ScannerFilter, ClassLoader) - Method in interface org.apache.maven.surefire.api.util.ScanResult
- argLine - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Arbitrary JVM options to set on the command line.
- argLine - Variable in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- arguments - Variable in class org.apache.maven.plugin.surefire.extensions.EventConsumerThread
- arguments - Variable in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- arguments - Variable in class org.apache.maven.surefire.booter.stream.CommandDecoder
- arguments - Variable in class org.apache.maven.surefire.extensions.ForkChannel
- arrangeMethodStatistics(WrappedReportEntry, TestSetStats) - Method in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- array - Variable in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.Segment
- artifacts - Variable in class org.apache.maven.plugin.surefire.TestClassPath
- asFailFast(boolean) - Method in class org.apache.maven.surefire.common.junit4.Notifier
- asHexString(byte[]) - Static method in class org.apache.maven.plugin.surefire.booterclient.ChecksumCalculator
- asString(RunOrder[]) - Static method in class org.apache.maven.surefire.api.util.RunOrder
- assumption(RunMode, Long, String, String, String, String, String) - Static method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- asTestLeaf(Description) - Method in class org.apache.maven.surefire.junitcore.JUnitCoreRunListener
- AsynchronousRunner - Class in org.apache.maven.surefire.junitcore
-
Deprecated.
- AsynchronousRunner(ExecutorService) - Constructor for class org.apache.maven.surefire.junitcore.AsynchronousRunner
-
Deprecated.
- attachToThread() - Method in class org.apache.maven.surefire.junitcore.TestMethod
-
Deprecated.
- attachToThread() - Method in class org.apache.maven.surefire.junitcore.TestSet
-
Deprecated.
- autoDetectOneWellKnownProvider(ProviderInfo...) - Method in class org.apache.maven.surefire.providerapi.ProviderDetector
- availablePermits() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream
-
For testing purposes only.
- availableProcessors - Static variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputerUtil
- awaitClosed() - Method in class org.apache.maven.surefire.extensions.util.CountdownCloseable
-
Waiting for one Thread in
CommandlineExecutor.awaitExit()
. - awaitExit() - Method in class org.apache.maven.surefire.extensions.util.CommandlineExecutor
- awaitMax() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.QueueSynchronizer.SyncT2
- awaitNext() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.QueueSynchronizer
- awaitNextCommand() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream
- awaitNextTest() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestProvidingInputStream
- awaitNextTest() - Method in class org.apache.maven.surefire.booter.CommandReader
- awaitResultsDone(Collection<Future<RunResult>>, ExecutorService) - Static method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- awaitStarted() - Method in interface org.apache.maven.surefire.api.provider.CommandChainReader
- awaitStarted() - Method in class org.apache.maven.surefire.booter.CommandReader
B
- BALANCED - Static variable in class org.apache.maven.surefire.api.util.RunOrder
- balancer - Variable in class org.apache.maven.surefire.junitcore.pc.Scheduler
- balancer - Variable in class org.apache.maven.surefire.junitcore.pc.ThreadResourcesBalancer
- balancer(int, boolean) - Static method in class org.apache.maven.surefire.junitcore.pc.BalancerFactory
- Balancer - Interface in org.apache.maven.surefire.junitcore.pc
-
The Balancer controls the maximum of concurrent threads in the current Scheduler(s) and prevents from own thread resources exhaustion if other group of schedulers share the same pool of threads.
- BalancerFactory - Class in org.apache.maven.surefire.junitcore.pc
- BalancerFactory() - Constructor for class org.apache.maven.surefire.junitcore.pc.BalancerFactory
- barrier - Variable in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream
- barrier - Variable in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestProvidingInputStream
- basedir - Variable in class org.apache.maven.plugin.failsafe.VerifyMojo
-
The base directory of the project being tested.
- basedir - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
The base directory of the project being tested.
- basedir - Variable in class org.apache.maven.plugin.surefire.util.DirectoryScanner
- basedir - Variable in class org.apache.maven.plugin.surefire.util.FileScanner
- basedir - Variable in class org.apache.maven.surefire.api.util.DefaultDirectoryScanner
-
Deprecated.
- baseProviderFactory - Variable in class org.apache.maven.surefire.booter.SurefireReflector
- BaseProviderFactory - Class in org.apache.maven.surefire.api.booter
- BaseProviderFactory(boolean) - Constructor for class org.apache.maven.surefire.api.booter.BaseProviderFactory
- bb - Variable in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.Memento
- beforeExecute() - Method in class org.apache.maven.surefire.junitcore.pc.Scheduler
- beforeInvocation(IInvokedMethod, ITestResult) - Method in class org.apache.maven.surefire.testng.utils.FailFastNotifier
- beforeNextCommand() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.DefaultCommandReader
-
Possibly waiting for next command (see
DefaultCommandReader.nextCommand()
) unless the stream is atomically closed (seeCommandReader.isClosed()
returnstrue
) before this method has returned. - beforeNextCommand() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream
- beforeNextCommand() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestProvidingInputStream
- beforeRunQuietly() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputer
- binaryDumpStreamFile - Variable in class org.apache.maven.surefire.api.booter.DumpErrorSingleton
- bindCommandReader(CommandReader, WritableByteChannel) - Method in class org.apache.maven.plugin.surefire.extensions.LegacyForkChannel
- bindCommandReader(CommandReader, WritableByteChannel) - Method in class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel
- bindCommandReader(CommandReader, WritableByteChannel) - Method in class org.apache.maven.surefire.extensions.ForkChannel
-
Binds command handler to the channel.
- bindCommandSender(AsynchronousSocketChannel) - Method in class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel.CommandBindings
- bindErrorStream(int, CountdownCloseable, CommandlineStreams, Object) - Static method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- bindEventHandler(AsynchronousSocketChannel) - Method in class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel.EventBindings
- bindEventHandler(EventHandler<Event>, CountdownCloseable, ReadableByteChannel) - Method in class org.apache.maven.plugin.surefire.extensions.LegacyForkChannel
- bindEventHandler(EventHandler<Event>, CountdownCloseable, ReadableByteChannel) - Method in class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel
- bindEventHandler(EventHandler<Event>, CountdownCloseable, ReadableByteChannel) - Method in class org.apache.maven.surefire.extensions.ForkChannel
-
Starts a Thread reading the events.
- bindings - Variable in class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel
- Bindings(int) - Constructor for class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel.Bindings
- BiProperty<P1,
P2> - Class in org.apache.maven.surefire.api.booter -
Internal generic wrapper.
- BiProperty(P1, P2) - Constructor for class org.apache.maven.surefire.api.booter.BiProperty
- BlockingIterator() - Constructor for class org.apache.maven.surefire.booter.LazyTestsToRun.BlockingIterator
- BOOLEAN_NON_NULL_OBJECT - Static variable in class org.apache.maven.surefire.api.stream.AbstractStreamEncoder
- BOOLEAN_NULL_OBJECT - Static variable in class org.apache.maven.surefire.api.stream.AbstractStreamEncoder
- booterClasspath - Variable in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- BOOTERCODE_BYE - Enum constant in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
-
This is the opcode "bye".
- BOOTERCODE_CONSOLE_DEBUG - Enum constant in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
-
This is the opcode "console-debug-log".
- BOOTERCODE_CONSOLE_ERROR - Enum constant in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
-
This is the opcode "console-error-log".
- BOOTERCODE_CONSOLE_INFO - Enum constant in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
-
This is the opcode "console-info-log".
- BOOTERCODE_CONSOLE_WARNING - Enum constant in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
-
This is the opcode "console-warning-log".
- BOOTERCODE_JVM_EXIT_ERROR - Enum constant in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
-
This is the opcode "jvm-exit-error".
- BOOTERCODE_NEXT_TEST - Enum constant in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
-
This is the opcode "next-test".
- BOOTERCODE_STDERR - Enum constant in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
-
This is the opcode "std-err-stream".
- BOOTERCODE_STDERR_NEW_LINE - Enum constant in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
-
This is the opcode "std-err-stream-new-line".
- BOOTERCODE_STDOUT - Enum constant in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
-
This is the opcode "std-out-stream".
- BOOTERCODE_STDOUT_NEW_LINE - Enum constant in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
-
This is the opcode "std-out-stream-new-line".
- BOOTERCODE_STOP_ON_NEXT_TEST - Enum constant in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
-
This is the opcode "stop-on-next-test".
- BOOTERCODE_SYSPROPS - Enum constant in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
-
This is the opcode "sys-prop".
- BOOTERCODE_TEST_ASSUMPTIONFAILURE - Enum constant in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
-
This is the opcode "test-assumption-failure".
- BOOTERCODE_TEST_ERROR - Enum constant in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
-
This is the opcode "test-error".
- BOOTERCODE_TEST_FAILED - Enum constant in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
-
This is the opcode "test-failed".
- BOOTERCODE_TEST_SKIPPED - Enum constant in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
-
This is the opcode "test-skipped".
- BOOTERCODE_TEST_STARTING - Enum constant in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
-
This is the opcode "test-starting".
- BOOTERCODE_TEST_SUCCEEDED - Enum constant in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
-
This is the opcode "test-succeeded".
- BOOTERCODE_TESTSET_COMPLETED - Enum constant in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
-
This is the opcode "testset-completed".
- BOOTERCODE_TESTSET_STARTING - Enum constant in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
-
This is the opcode "testset-starting".
- BooterConstants - Class in org.apache.maven.surefire.booter
-
Constants used by the serializer/deserializer
- BooterConstants() - Constructor for class org.apache.maven.surefire.booter.BooterConstants
- BooterDeserializer - Class in org.apache.maven.surefire.booter
-
Knows how to serialize and deserialize the booter configuration.
- BooterDeserializer(InputStream) - Constructor for class org.apache.maven.surefire.booter.BooterDeserializer
- booterParameters - Variable in class org.apache.maven.surefire.booter.SurefireReflector
- BooterSerializer - Class in org.apache.maven.plugin.surefire.booterclient
-
Knows how to serialize and deserialize the booter configuration.
- BooterSerializer(ForkConfiguration) - Constructor for class org.apache.maven.plugin.surefire.booterclient.BooterSerializer
- BRIEF - Static variable in class org.apache.maven.plugin.surefire.report.ConsoleReporter
- briefOrPlainFormat - Variable in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- buffer - Variable in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.BufferedStream
- BUFFER_SIZE - Static variable in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- BUFFER_SIZE - Static variable in class org.apache.maven.surefire.api.util.internal.Channels
- BufferedStream(int) - Constructor for class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.BufferedStream
- build() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder
- buildComputer() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- builder - Variable in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream
- buildLauncherDiscoveryRequestForRerunFailures(RunListenerAdapter) - Method in class org.apache.maven.surefire.junitplatform.JUnitPlatformProvider
- BUSYBOX_CMD_OUT_PATTERN - Static variable in class org.apache.maven.surefire.booter.PpidChecker
- bye() - Method in interface org.apache.maven.surefire.api.booter.MasterProcessChannelEncoder
-
Say BYE on exit.
- bye() - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- BYE_ACK - Enum constant in enum class org.apache.maven.surefire.api.booter.MasterProcessCommand
- BYE_ACK - Static variable in class org.apache.maven.surefire.api.booter.Command
- ByeListener() - Constructor for class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.ByeListener
- BYTE_LENGTH - Static variable in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- ByteConstantsHolder() - Constructor for class org.apache.maven.plugin.surefire.report.StatelessXmlReporter.ByteConstantsHolder
C
- c1 - Variable in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter.EncodingOutputStream
- c2 - Variable in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter.EncodingOutputStream
- cachableCommands - Variable in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream
- cachableCommands - Variable in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder
- CachableCommands() - Constructor for class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder.CachableCommands
- cache - Variable in class org.apache.maven.plugin.surefire.report.Utf8RecodingDeferredFileOutputStream
- cache - Variable in class org.apache.maven.surefire.api.testset.ResolvedTest.ClassMatcher
-
Deprecated.
- cache - Variable in class org.apache.maven.surefire.api.testset.ResolvedTest.MethodMatcher
-
Deprecated.
- CACHE_SIZE - Static variable in class org.apache.maven.plugin.surefire.report.Utf8RecodingDeferredFileOutputStream
- calculateEffectiveProperties(Properties, Map<String, String>, Properties, SurefireProperties) - Static method in class org.apache.maven.plugin.surefire.SurefireProperties
- callListeners(Command) - Method in class org.apache.maven.surefire.booter.CommandReader.CommandRunnable
- cancel() - Method in class org.apache.maven.surefire.api.provider.AbstractProvider
- cancel() - Method in interface org.apache.maven.surefire.api.provider.SurefireProvider
-
Makes an attempt at cancelling the current run, giving the provider a chance to notify reporting that the remaining tests have been cancelled due to timeout.
- cancel() - Method in class org.apache.maven.surefire.booter.ProviderFactory.ProviderProxy
- cancelPingScheduler() - Method in class org.apache.maven.surefire.booter.ForkedBooter
- canContinue() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.DefaultCommandReader
-
Opposite to
CommandReader.isClosed()
. - canExecuteLocalUnixPs() - Static method in class org.apache.maven.surefire.booter.PpidChecker
- canExecuteProviderWithModularPath(Platform, ResolvePathResultWrapper) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- canExecuteStandardUnixPs() - Static method in class org.apache.maven.surefire.booter.PpidChecker
- canExecuteUnixPs() - Static method in class org.apache.maven.surefire.booter.PpidChecker
- canMatchExclusive(String, String) - Method in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- canMatchExclusiveAll(String, String) - Method in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- canMatchExclusiveClasses(String, String) - Method in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- canMatchExclusiveMethods(String, String) - Method in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- canSchedule - Variable in class org.apache.maven.surefire.junitcore.pc.SchedulingStrategy
- canSchedule() - Method in class org.apache.maven.surefire.junitcore.pc.Scheduler
- canSchedule() - Method in class org.apache.maven.surefire.junitcore.pc.Scheduler.Controller
- canSchedule() - Method in class org.apache.maven.surefire.junitcore.pc.SchedulingStrategy
- canSchedule(Runner) - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- canUse() - Method in class org.apache.maven.surefire.booter.PpidChecker
- canUse() - Method in class org.apache.maven.surefire.booter.ProcessInfo
- canUse(String) - Method in class org.apache.maven.surefire.booter.spi.LegacyMasterProcessChannelProcessorFactory
- canUse(String) - Method in class org.apache.maven.surefire.booter.spi.SurefireMasterProcessChannelProcessorFactory
- canUse(String) - Method in interface org.apache.maven.surefire.spi.MasterProcessChannelProcessorFactory
-
Evaluates the
channelConfig
. - canUseNewPingMechanism(PpidChecker) - Static method in class org.apache.maven.surefire.booter.ForkedBooter
- capacity - Variable in class org.apache.maven.surefire.junitcore.pc.Concurrency
- categories - Variable in class org.apache.maven.surefire.common.junit48.JUnit48Reflector
- CATEGORIES - Static variable in class org.apache.maven.surefire.common.junit48.JUnit48Reflector
- CategorizedReportEntry - Class in org.apache.maven.surefire.api.report
- CategorizedReportEntry(RunMode, Long, String, String, String) - Constructor for class org.apache.maven.surefire.api.report.CategorizedReportEntry
- CategorizedReportEntry(RunMode, Long, String, String, String, String, String, StackTraceWriter, Integer, String, Map<String, String>) - Constructor for class org.apache.maven.surefire.api.report.CategorizedReportEntry
- CategorizedReportEntry(RunMode, Long, String, String, String, StackTraceWriter, Integer) - Constructor for class org.apache.maven.surefire.api.report.CategorizedReportEntry
- CategorizedReportEntry(RunMode, Long, String, String, String, StackTraceWriter, Integer, String) - Constructor for class org.apache.maven.surefire.api.report.CategorizedReportEntry
- category - Variable in class org.apache.maven.surefire.common.junit48.JUnit48Reflector
- CATEGORY - Static variable in class org.apache.maven.surefire.common.junit48.JUnit48Reflector
- causeToString(Throwable, StackTraceFilter) - Static method in class org.apache.maven.surefire.report.SmartStackTraceParser
- cb - Variable in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.Memento
- CDATA_END_BYTES - Static variable in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter.ByteConstantsHolder
- CDATA_ESCAPE_STRING_BYTES - Static variable in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter.ByteConstantsHolder
- CDATA_START_BYTES - Static variable in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter.ByteConstantsHolder
- channel - Variable in class org.apache.maven.plugin.surefire.extensions.EventConsumerThread
- channel - Variable in class org.apache.maven.plugin.surefire.extensions.StreamFeeder
- channel - Variable in class org.apache.maven.plugin.surefire.report.Utf8RecodingDeferredFileOutputStream
- channel - Variable in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- channel - Variable in class org.apache.maven.surefire.extensions.util.LineConsumerThread
- channelProcessorFactory - Variable in class org.apache.maven.surefire.booter.ForkedBooter
- Channels - Class in org.apache.maven.surefire.api.util.internal
- Channels() - Constructor for class org.apache.maven.surefire.api.util.internal.Channels
- charset - Variable in class org.apache.maven.surefire.booter.PpidChecker.ProcessInfoConsumer
- checkArguments(AbstractStreamDecoder.Memento, int) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- checkDelimiter(AbstractStreamDecoder.Memento) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- checkError() - Method in interface org.apache.maven.surefire.api.booter.MasterProcessChannelEncoder
- checkError() - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- checkforTestAnnotatedMethod(Class) - Method in class org.apache.maven.surefire.common.junit4.JUnit4TestChecker
- checkHeader(AbstractStreamDecoder.Memento) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- checkIfTestSetCanBeReported(TestSet) - Method in class org.apache.maven.surefire.junitcore.ClassesParallelRunListener
-
Deprecated.
- checkIfTestSetCanBeReported(TestSet) - Method in class org.apache.maven.surefire.junitcore.ConcurrentRunListener
-
Deprecated.
- checkIfTestSetCanBeReported(TestSet) - Method in class org.apache.maven.surefire.junitcore.MethodsParallelRunListener
-
Deprecated.
- checkIllegalCharacters(String...) - Static method in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- checkMethodFilterInIncludesExcludes(Iterable<String>) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- checkNonForkedThreads(String) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- checkProcessInfo() - Method in class org.apache.maven.surefire.booter.PpidChecker
- ChecksumCalculator - Class in org.apache.maven.plugin.surefire.booterclient
- ChecksumCalculator() - Constructor for class org.apache.maven.plugin.surefire.booterclient.ChecksumCalculator
- checksumItems - Variable in class org.apache.maven.plugin.surefire.booterclient.ChecksumCalculator
- checkThreadCountEntity(int, String) - Static method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- checkValid() - Method in class org.apache.maven.surefire.booter.ProcessInfo
- checkValid(Scanner) - Static method in class org.apache.maven.surefire.booter.PpidChecker
- CHILD_DELEGATION - Static variable in class org.apache.maven.surefire.booter.AbstractPathConfiguration
- childDelegation - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
When false it makes tests run using the standard classloader delegation instead of the default Maven isolated classloader.
- childDelegation - Variable in class org.apache.maven.surefire.booter.AbstractPathConfiguration
- childDelegation - Variable in class org.apache.maven.surefire.booter.IsolatedClassLoader
- CIt() - Constructor for class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder.CIt
- CLASS - Enum constant in enum class org.apache.maven.surefire.api.testset.ResolvedTest.Type
-
Deprecated.
- CLASS_FILE_EXTENSION - Static variable in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- CLASS_FILE_EXTENSION - Static variable in class org.apache.maven.surefire.common.junit48.RequestedTest
- classes - Variable in class org.apache.maven.surefire.api.util.DefaultScanResult
- classes - Variable in class org.apache.maven.surefire.junitcore.pc.Concurrency
- classes - Variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- classes - Variable in class org.apache.maven.surefire.junitcore.pc.RunnerCounter
- CLASSES - Enum constant in enum class org.apache.maven.surefire.junitcore.pc.Type
- classesDirectory - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
The path representing project JAR file, if exists; Otherwise the directory containing generated classes of the project being tested.
- classesDirectory - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
The directory containing generated classes of the project being tested.
- classesDirectory - Variable in class org.apache.maven.plugin.surefire.TestClassPath
- ClassesIterable(MasterProcessChannelEncoder) - Constructor for class org.apache.maven.surefire.booter.CommandReader.ClassesIterable
- ClassesIterator() - Constructor for class org.apache.maven.surefire.api.util.TestsToRun.ClassesIterator
- ClassesIterator(MasterProcessChannelEncoder) - Constructor for class org.apache.maven.surefire.booter.CommandReader.ClassesIterator
- ClassesParallelRunListener - Class in org.apache.maven.surefire.junitcore
-
Deprecated.
- ClassesParallelRunListener(Map<String, TestSet>, ReporterFactory) - Constructor for class org.apache.maven.surefire.junitcore.ClassesParallelRunListener
-
Deprecated.
- classFile(Class<?>) - Method in class org.apache.maven.surefire.common.junit48.RequestedTest
- classifier - Variable in class org.apache.maven.surefire.api.testset.TestArtifactInfo
- classIndex - Variable in class org.apache.maven.surefire.report.ClassMethodIndexer
- classLoader - Variable in class org.apache.maven.surefire.booter.ProviderFactory
- classLoaderConfiguration - Variable in class org.apache.maven.surefire.booter.StartupConfiguration
- ClassLoaderConfiguration - Class in org.apache.maven.surefire.booter
-
Configuration for forking tests.
- ClassLoaderConfiguration(boolean, boolean) - Constructor for class org.apache.maven.surefire.booter.ClassLoaderConfiguration
- classMatcher - Variable in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- ClassMatcher() - Constructor for class org.apache.maven.surefire.api.testset.ResolvedTest.ClassMatcher
-
Deprecated.
- classMethod - Variable in class org.apache.maven.surefire.api.runorder.RunEntryStatistics
- ClassMethod - Class in org.apache.maven.surefire.api.util.internal
-
Data transfer object of class and method literals.
- ClassMethod(String, String) - Constructor for class org.apache.maven.surefire.api.util.internal.ClassMethod
- classMethodCounts - Variable in class org.apache.maven.surefire.junitcore.ConcurrentRunListener
-
Deprecated.
- classMethodCounts - Variable in class org.apache.maven.surefire.junitcore.JUnitCoreRunListener
- classMethodIndexer - Variable in class org.apache.maven.surefire.common.junit4.JUnit4RunListener
- classMethodIndexer - Variable in class org.apache.maven.surefire.junit.JUnit3Reporter
- classMethodIndexer - Variable in class org.apache.maven.surefire.junit4.JUnit4Provider
- classMethodIndexer - Variable in class org.apache.maven.surefire.junitcore.TestSet
-
Deprecated.
- classMethodIndexer - Variable in class org.apache.maven.surefire.junitplatform.RunListenerAdapter
- classMethodIndexer - Variable in class org.apache.maven.surefire.testng.TestNGReporter
- ClassMethodIndexer - Class in org.apache.maven.surefire.report
-
Creates an index for class/method.
- ClassMethodIndexer() - Constructor for class org.apache.maven.surefire.report.ClassMethodIndexer
- className - Variable in class org.apache.maven.surefire.api.runorder.Priority
- className - Variable in class org.apache.maven.surefire.report.ClassNameStackTraceFilter
- ClassNameStackTraceFilter - Class in org.apache.maven.surefire.report
-
Filters stacktrace element by class name.
- ClassNameStackTraceFilter(String) - Constructor for class org.apache.maven.surefire.report.ClassNameStackTraceFilter
- Classpath - Class in org.apache.maven.surefire.booter
-
An ordered list of classpath elements with set behaviour A Classpath is immutable and thread safe.
- Classpath() - Constructor for class org.apache.maven.surefire.booter.Classpath
- Classpath(Collection<String>) - Constructor for class org.apache.maven.surefire.booter.Classpath
- Classpath(Classpath, String) - Constructor for class org.apache.maven.surefire.booter.Classpath
- CLASSPATH - Static variable in class org.apache.maven.surefire.booter.AbstractPathConfiguration
- classpathCache - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- ClasspathCache - Class in org.apache.maven.plugin.surefire
-
Deprecated.
- ClasspathCache() - Constructor for class org.apache.maven.plugin.surefire.AbstractSurefireMojo.ClasspathCache
- ClasspathCache() - Constructor for class org.apache.maven.plugin.surefire.ClasspathCache
-
Deprecated.
- classpathConfiguration - Variable in class org.apache.maven.surefire.booter.StartupConfiguration
- ClasspathConfiguration - Class in org.apache.maven.surefire.booter
-
Represents the classpaths for the BooterConfiguration.
- ClasspathConfiguration(boolean, boolean) - Constructor for class org.apache.maven.surefire.booter.ClasspathConfiguration
- ClasspathConfiguration(Classpath, Classpath, Classpath, boolean, boolean) - Constructor for class org.apache.maven.surefire.booter.ClasspathConfiguration
- ClasspathConfiguration(PropertiesWrapper) - Constructor for class org.apache.maven.surefire.booter.ClasspathConfiguration
- classpathDependencyExcludes - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
List of dependencies to exclude from the test classpath.
- classpathDependencyScopeExclude - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
A dependency scope to exclude from the test classpath.
- ClasspathElementUri(String, boolean) - Constructor for class org.apache.maven.plugin.surefire.booterclient.JarManifestForkConfiguration.ClasspathElementUri
- ClasspathForkConfiguration - Class in org.apache.maven.plugin.surefire.booterclient
- ClasspathForkConfiguration(Classpath, File, String, File, Properties, String, Map<String, String>, String[], boolean, int, boolean, Platform, ConsoleLogger, ForkNodeFactory) - Constructor for class org.apache.maven.plugin.surefire.booterclient.ClasspathForkConfiguration
- classpaths - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.ClasspathCache
- CLASSPATHS - Static variable in class org.apache.maven.plugin.surefire.ClasspathCache
-
Deprecated.
- classPattern - Variable in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- clazz - Variable in class org.apache.maven.surefire.api.runorder.PrioritizedTest
- clazz - Variable in class org.apache.maven.surefire.api.util.internal.ClassMethod
- clazz - Variable in class org.apache.maven.surefire.booter.CommandReader.ClassesIterator
- cleanTestHistoryMap() - Method in class org.apache.maven.plugin.surefire.report.NullStatelessXmlReporter
- cleanTestHistoryMap() - Method in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
-
Clean testClassMethodRunHistoryMap
- cleanupForkConfiguration(ForkConfiguration) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- clear() - Method in class org.apache.maven.plugin.surefire.SurefireProperties
- clear() - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.BufferedStream
- clearCapture() - Method in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- clearQueue() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.QueueSynchronizer
- clearShutdownState() - Method in class org.apache.maven.plugin.surefire.booterclient.Platform
- cli - Variable in class org.apache.maven.plugin.failsafe.VerifyMojo
- cli - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- cli - Variable in class org.apache.maven.surefire.extensions.util.CommandlineExecutor
- clientSocketChannel - Variable in class org.apache.maven.surefire.booter.spi.SurefireMasterProcessChannelProcessorFactory
- clone() - Method in class org.apache.maven.surefire.booter.Classpath
- clone(ClassLoader) - Method in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5ConsoleOutputReporter
- clone(ClassLoader) - Method in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5StatelessTestsetInfoReporter
- clone(ClassLoader) - Method in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5Xml30StatelessReporter
- clone(ClassLoader) - Method in class org.apache.maven.plugin.surefire.extensions.SurefireConsoleOutputReporter
- clone(ClassLoader) - Method in class org.apache.maven.plugin.surefire.extensions.SurefireStatelessReporter
- clone(ClassLoader) - Method in class org.apache.maven.plugin.surefire.extensions.SurefireStatelessTestsetInfoReporter
- clone(ClassLoader) - Method in class org.apache.maven.surefire.extensions.ConsoleOutputReporter
- clone(ClassLoader) - Method in class org.apache.maven.surefire.extensions.StatelessReporter
- clone(ClassLoader) - Method in class org.apache.maven.surefire.extensions.StatelessTestsetInfoReporter
- close() - Method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter.CloseableCloser
- close() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream
- close() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestProvidingInputStream
- close() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer
- close() - Method in class org.apache.maven.plugin.surefire.extensions.EventConsumerThread
- close() - Method in class org.apache.maven.plugin.surefire.extensions.LegacyForkChannel
- close() - Method in class org.apache.maven.plugin.surefire.extensions.StreamFeeder
- close() - Method in class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel
- close() - Method in class org.apache.maven.plugin.surefire.report.ConsoleOutputFileReporter
- close() - Method in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
- close() - Method in class org.apache.maven.plugin.surefire.report.DirectConsoleOutput
- close() - Method in class org.apache.maven.plugin.surefire.report.NullConsoleOutputReceiver
- close() - Method in interface org.apache.maven.plugin.surefire.report.ReportsMerger
- close() - Method in interface org.apache.maven.plugin.surefire.report.TestcycleConsoleOutputReceiver
- close() - Method in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- close() - Method in class org.apache.maven.surefire.api.booter.ForkingReporterFactory
- close() - Method in interface org.apache.maven.surefire.api.booter.MasterProcessChannelDecoder
- close() - Method in class org.apache.maven.surefire.api.report.ConsoleOutputCapture.ForwardingPrintStream
- close() - Method in interface org.apache.maven.surefire.api.report.ReporterFactory
-
Closes the factory, freeing resources allocated in the factory.
- close() - Method in class org.apache.maven.surefire.api.util.internal.AbstractNoninterruptibleReadableChannel
- close() - Method in class org.apache.maven.surefire.api.util.internal.AbstractNoninterruptibleWritableChannel
- close() - Method in class org.apache.maven.surefire.booter.spi.AbstractMasterProcessChannelProcessorFactory
- close() - Method in class org.apache.maven.surefire.booter.spi.CommandChannelDecoder
- close() - Method in class org.apache.maven.surefire.booter.spi.SurefireMasterProcessChannelProcessorFactory
- close() - Method in class org.apache.maven.surefire.booter.stream.CommandDecoder
- close() - Method in interface org.apache.maven.surefire.extensions.CommandReader
- close() - Method in interface org.apache.maven.surefire.extensions.ConsoleOutputReportEventListener
- close() - Method in class org.apache.maven.surefire.extensions.ForkChannel
- close() - Method in class org.apache.maven.surefire.extensions.util.CommandlineExecutor
- close() - Method in class org.apache.maven.surefire.extensions.util.CommandlineStreams
- close() - Method in class org.apache.maven.surefire.extensions.util.CountdownCloseable
- close() - Method in class org.apache.maven.surefire.extensions.util.LineConsumerThread
- close() - Method in class org.apache.maven.surefire.junitcore.ConfigurableParallelComputer
-
Deprecated.
- close() - Method in class org.apache.maven.surefire.junitplatform.LazyLauncher
- close() - Method in class org.apache.maven.surefire.stream.CommandEncoder
- close() - Method in class org.apache.maven.surefire.stream.EventDecoder
- close(boolean) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
- close(boolean) - Method in class org.apache.maven.plugin.surefire.report.ConsoleOutputFileReporter
- closeable - Variable in class org.apache.maven.surefire.extensions.util.CountdownCloseable
- CloseableCloser(int, Closeable...) - Constructor for class org.apache.maven.plugin.surefire.booterclient.ForkStarter.CloseableCloser
- CloseableDaemonThread - Class in org.apache.maven.surefire.extensions
-
The base thread class used to handle a stream, transforms the stream to an object.
- CloseableDaemonThread(String) - Constructor for class org.apache.maven.surefire.extensions.CloseableDaemonThread
- CloseableIterator<T> - Class in org.apache.maven.surefire.api.util
-
This iterator is marked as stopped if
CloseableIterator.isClosed()
returnstrue
. - CloseableIterator() - Constructor for class org.apache.maven.surefire.api.util.CloseableIterator
- closed - Variable in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream
- closed - Variable in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestProvidingInputStream
- closed - Variable in class org.apache.maven.plugin.surefire.report.Utf8RecodingDeferredFileOutputStream
- closed - Variable in class org.apache.maven.surefire.extensions.util.CommandlineStreams
- CLOSED - Static variable in class org.apache.maven.plugin.surefire.report.ConsoleOutputFileReporter
- CLOSED_TO_REOPEN - Static variable in class org.apache.maven.plugin.surefire.report.ConsoleOutputFileReporter
- closeExecutor(ExecutorService) - Method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- closeForkChannel() - Method in class org.apache.maven.surefire.booter.ForkedBooter
- closeImpl() - Method in class org.apache.maven.surefire.api.util.internal.AbstractNoninterruptibleReadableChannel
- closeImpl() - Method in class org.apache.maven.surefire.api.util.internal.AbstractNoninterruptibleWritableChannel
- closeLauncher() - Method in class org.apache.maven.surefire.junitplatform.JUnitPlatformProvider
- closeNullReportFile(ReportEntry) - Method in class org.apache.maven.plugin.surefire.report.ConsoleOutputFileReporter
- closeReportFile() - Method in class org.apache.maven.plugin.surefire.report.ConsoleOutputFileReporter
- collectAllTestIdentifiersInHierarchy(TestIdentifier) - Method in class org.apache.maven.surefire.junitplatform.RunListenerAdapter
- collectTests() - Method in class org.apache.maven.surefire.api.util.DefaultDirectoryScanner
-
Deprecated.
- CombinedCategoryFilter - Class in org.apache.maven.surefire.common.junit48
- CombinedCategoryFilter(Collection<Filter>, Collection<Filter>) - Constructor for class org.apache.maven.surefire.common.junit48.CombinedCategoryFilter
- combinedFilter - Variable in class org.apache.maven.surefire.common.junit48.MethodFilter
- COMMA - Static variable in class org.apache.maven.plugin.surefire.report.TestSetStats
- COMMA_PATTERN - Static variable in class org.apache.maven.surefire.junitplatform.RunListenerAdapter
- command - Variable in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder.Node
- command - Variable in class org.apache.maven.surefire.api.booter.Command
- Command - Class in org.apache.maven.surefire.api.booter
-
Encapsulates data and command sent from master to forked process.
- Command(MasterProcessCommand) - Constructor for class org.apache.maven.surefire.api.booter.Command
- Command(MasterProcessCommand, String) - Constructor for class org.apache.maven.surefire.api.booter.Command
- COMMAND_TYPES - Static variable in enum class org.apache.maven.surefire.api.booter.MasterProcessCommand
- COMMAND_WITH_ONE_STRING - Static variable in class org.apache.maven.surefire.booter.stream.CommandDecoder
- COMMAND_WITHOUT_DATA - Static variable in class org.apache.maven.surefire.booter.stream.CommandDecoder
- commandBindings - Variable in class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel
- CommandBindings(CommandReader) - Constructor for class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel.CommandBindings
- CommandChainReader - Interface in org.apache.maven.surefire.api.provider
-
Hiding CommandReader instance in provider.
- CommandChannelDecoder - Class in org.apache.maven.surefire.booter.spi
-
magic number : opcode [: opcode specific data]*
- CommandChannelDecoder(ReadableByteChannel, ForkNodeArguments) - Constructor for class org.apache.maven.surefire.booter.spi.CommandChannelDecoder
- CommandDecoder - Class in org.apache.maven.surefire.booter.stream
- CommandDecoder(ReadableByteChannel, ForkNodeArguments) - Constructor for class org.apache.maven.surefire.booter.stream.CommandDecoder
- CommandEncoder - Class in org.apache.maven.surefire.stream
- CommandEncoder(WritableByteChannel) - Constructor for class org.apache.maven.surefire.stream.CommandEncoder
- Commandline - Class in org.apache.maven.plugin.surefire.booterclient.lazytestprovider
-
A
Commandline
implementation. - Commandline() - Constructor for class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.Commandline
-
for testing purposes only
- Commandline(String[]) - Constructor for class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.Commandline
- CommandlineExecutor - Class in org.apache.maven.surefire.extensions.util
-
Programming model with this class:
- CommandlineExecutor(Commandline, CountdownCloseable) - Constructor for class org.apache.maven.surefire.extensions.util.CommandlineExecutor
- CommandlineExecutor.ProcessHook - Class in org.apache.maven.surefire.extensions.util
- CommandLineOption - Enum Class in org.apache.maven.surefire.api.cli
-
CLI options.
- CommandLineOption() - Constructor for enum class org.apache.maven.surefire.api.cli.CommandLineOption
- commandLineOptions() - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
- commandLineOptions() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- commandLineOptions(MavenSession, PluginConsoleLogger) - Static method in class org.apache.maven.plugin.surefire.SurefireHelper
- commandLineOptionsClass - Variable in class org.apache.maven.surefire.booter.SurefireReflector
- CommandlineStreams - Class in org.apache.maven.surefire.extensions.util
- CommandlineStreams(Process) - Constructor for class org.apache.maven.surefire.extensions.util.CommandlineStreams
- CommandListener - Interface in org.apache.maven.surefire.api.provider
-
Command listener interface.
- commandReader - Variable in class org.apache.maven.plugin.surefire.extensions.StreamFeeder
- commandReader - Variable in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- commandReader - Variable in class org.apache.maven.surefire.booter.ForkedBooter
- commandReader - Variable in class org.apache.maven.surefire.booter.LazyTestsToRun
- CommandReader - Class in org.apache.maven.surefire.booter
-
Reader of commands coming from plugin(master) process.
- CommandReader - Interface in org.apache.maven.surefire.extensions
-
Stream reader returns bytes which ar finally sent to the forked jvm.
- CommandReader(MasterProcessChannelDecoder, Shutdown, ConsoleLogger) - Constructor for class org.apache.maven.surefire.booter.CommandReader
- CommandReader.ClassesIterable - Class in org.apache.maven.surefire.booter
- CommandReader.ClassesIterator - Class in org.apache.maven.surefire.booter
- CommandReader.CommandRunnable - Class in org.apache.maven.surefire.booter
- commandReaderBindings - Variable in class org.apache.maven.plugin.surefire.extensions.LegacyForkChannel
- commandReaderBindings - Variable in class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel
- CommandRunnable() - Constructor for class org.apache.maven.surefire.booter.CommandReader.CommandRunnable
- commands - Variable in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestProvidingInputStream
- commands - Variable in class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel.CommandBindings
- commandsReader - Variable in class org.apache.maven.surefire.junit4.JUnit4Provider
- commandsReader - Variable in class org.apache.maven.surefire.junitcore.JUnitCoreProvider
- commandsReader - Variable in class org.apache.maven.surefire.testng.TestNGProvider
- commandThread - Variable in class org.apache.maven.surefire.booter.CommandReader
- COMMENT_END - Static variable in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter.ByteConstantsHolder
- COMMENT_START - Static variable in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter.ByteConstantsHolder
- CommonReflector - Class in org.apache.maven.plugin.surefire
- CommonReflector(ClassLoader) - Constructor for class org.apache.maven.plugin.surefire.CommonReflector
- compare(PrioritizedTest, PrioritizedTest) - Method in class org.apache.maven.surefire.api.runorder.RunEntryStatisticsMap.PrioritizedTestComparator
- compare(Priority, Priority) - Method in class org.apache.maven.surefire.api.runorder.RunEntryStatisticsMap.LeastFailureComparator
- compare(Priority, Priority) - Method in class org.apache.maven.surefire.api.runorder.RunEntryStatisticsMap.TestRuntimeComparator
- compare(RunEntryStatistics, RunEntryStatistics) - Method in class org.apache.maven.surefire.api.runorder.RunEntryStatisticsMap.RunCountComparator
- Completable - Interface in org.apache.maven.surefire.extensions
-
Forks the execution of task and the task completion.
- complete() - Method in interface org.apache.maven.surefire.extensions.Completable
- completedCount - Variable in class org.apache.maven.plugin.surefire.report.TestSetStats
- completedCount - Variable in class org.apache.maven.surefire.api.suite.RunResult
- completedCount - Variable in class org.apache.maven.surefire.report.RunStatistics
- computeElapsedTime(TestIdentifier) - Method in class org.apache.maven.surefire.junitplatform.RunListenerAdapter
- concatenateWithTestGroup(MessageBuilder, ReportEntry, boolean) - Static method in class org.apache.maven.plugin.surefire.report.TestSetStats
-
Append the test set message for a report.
- Concurrency - Class in org.apache.maven.surefire.junitcore.pc
- Concurrency() - Constructor for class org.apache.maven.surefire.junitcore.pc.Concurrency
- concurrencyForUnlimitedThreads(JUnitCoreParameters) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerUtil
- concurrencyFromAllThreadCounts(JUnitCoreParameters) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerUtil
- concurrencyFromAllThreadCountsButUnspecifiedLeafCount(JUnitCoreParameters, RunnerCounter) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerUtil
- concurrencyFromThreadCounts(JUnitCoreParameters) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerUtil
- ConcurrencyUtils - Class in org.apache.maven.surefire.api.util.internal
-
Concurrency utilities.
- ConcurrencyUtils() - Constructor for class org.apache.maven.surefire.api.util.internal.ConcurrencyUtils
- ConcurrentRunListener - Class in org.apache.maven.surefire.junitcore
-
Deprecated.
- ConcurrentRunListener(ReporterFactory, boolean, Map<String, TestSet>) - Constructor for class org.apache.maven.surefire.junitcore.ConcurrentRunListener
-
Deprecated.
- ConfigurableParallelComputer - Class in org.apache.maven.surefire.junitcore
-
Deprecated.
- ConfigurableParallelComputer() - Constructor for class org.apache.maven.surefire.junitcore.ConfigurableParallelComputer
-
Deprecated.
- ConfigurableParallelComputer(boolean, boolean) - Constructor for class org.apache.maven.surefire.junitcore.ConfigurableParallelComputer
-
Deprecated.
- ConfigurableParallelComputer(boolean, boolean, Integer, boolean) - Constructor for class org.apache.maven.surefire.junitcore.ConfigurableParallelComputer
-
Deprecated.
- ConfigurableParallelComputer(boolean, boolean, ExecutorService, boolean) - Constructor for class org.apache.maven.surefire.junitcore.ConfigurableParallelComputer
-
Deprecated.
- ConfigurableProviderInfo - Interface in org.apache.maven.surefire.providerapi
- CONFIGURATION_PARAMETERS - Static variable in class org.apache.maven.surefire.junitplatform.JUnitPlatformProvider
- ConfigurationAwareTestNGReporter - Class in org.apache.maven.surefire.testng
-
Just like TestNGReporter, but explicitly implements IResultListener; this interface is new in TestNG 5.5
- ConfigurationAwareTestNGReporter(TestReportListener<TestOutputReportEntry>) - Constructor for class org.apache.maven.surefire.testng.ConfigurationAwareTestNGReporter
- configurationParameters - Variable in class org.apache.maven.surefire.junitplatform.JUnitPlatformProvider
- Configurator - Interface in org.apache.maven.surefire.testng.conf
-
Configurator for passing configuration properties to TestNG
- configure(TestNG, Map<String, String>) - Method in class org.apache.maven.surefire.testng.conf.AbstractDirectConfigurator
- configure(TestNG, Map<String, String>) - Method in interface org.apache.maven.surefire.testng.conf.Configurator
- configure(TestNG, Map<String, String>) - Method in class org.apache.maven.surefire.testng.conf.TestNGMapConfigurator
- configure(XmlSuite, Map<String, String>) - Method in class org.apache.maven.surefire.testng.conf.AbstractDirectConfigurator
- configure(XmlSuite, Map<String, String>) - Method in interface org.apache.maven.surefire.testng.conf.Configurator
- configure(XmlSuite, Map<String, String>) - Method in class org.apache.maven.surefire.testng.conf.TestNG510Configurator
- configure(XmlSuite, Map<String, String>) - Method in class org.apache.maven.surefire.testng.conf.TestNG740Configurator
- configure(XmlSuite, Map<String, String>) - Method in class org.apache.maven.surefire.testng.conf.TestNGMapConfigurator
- configureInstance(Object, Map<String, String>) - Method in class org.apache.maven.surefire.testng.conf.AbstractDirectConfigurator
- connect(String) - Method in class org.apache.maven.surefire.booter.spi.LegacyMasterProcessChannelProcessorFactory
- connect(String) - Method in class org.apache.maven.surefire.booter.spi.SurefireMasterProcessChannelProcessorFactory
- connect(String) - Method in interface org.apache.maven.surefire.spi.MasterProcessChannelProcessorFactory
-
Open a new connection.
- ConsoleDebugEvent - Class in org.apache.maven.surefire.api.event
-
The event with a message for console debug level.
- ConsoleDebugEvent(String) - Constructor for class org.apache.maven.surefire.api.event.ConsoleDebugEvent
- consoleDebugLog(String) - Method in interface org.apache.maven.surefire.api.booter.MasterProcessChannelEncoder
-
Debug log.
- consoleDebugLog(String) - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- ConsoleErrorEvent - Class in org.apache.maven.surefire.api.event
-
The event with a message for console error level.
- ConsoleErrorEvent(StackTraceWriter) - Constructor for class org.apache.maven.surefire.api.event.ConsoleErrorEvent
- consoleErrorEventListener - Variable in class org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessEventNotifier
- consoleErrorLog(String) - Method in interface org.apache.maven.surefire.api.booter.MasterProcessChannelEncoder
-
Error log.
- consoleErrorLog(String) - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- consoleErrorLog(String, Throwable) - Method in interface org.apache.maven.surefire.api.booter.MasterProcessChannelEncoder
-
Error log.
- consoleErrorLog(String, Throwable) - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- consoleErrorLog(Throwable) - Method in interface org.apache.maven.surefire.api.booter.MasterProcessChannelEncoder
-
Error log.
- consoleErrorLog(Throwable) - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- consoleErrorLog(StackTraceWriter, boolean) - Method in interface org.apache.maven.surefire.api.booter.MasterProcessChannelEncoder
-
Error log.
- consoleErrorLog(StackTraceWriter, boolean) - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- consoleEventListeners - Variable in class org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessEventNotifier
- ConsoleInfoEvent - Class in org.apache.maven.surefire.api.event
-
The event with a message for console info level.
- ConsoleInfoEvent(String) - Constructor for class org.apache.maven.surefire.api.event.ConsoleInfoEvent
- consoleInfoLog(String) - Method in interface org.apache.maven.surefire.api.booter.MasterProcessChannelEncoder
-
Info log.
- consoleInfoLog(String) - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- ConsoleListener() - Constructor for class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.ConsoleListener
- consoleLogger - Variable in class org.apache.maven.plugin.failsafe.VerifyMojo
- consoleLogger - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- consoleLogger - Variable in class org.apache.maven.plugin.surefire.CommonReflector
- consoleLogger - Variable in class org.apache.maven.plugin.surefire.InPluginVMSurefireStarter
- consoleLogger - Variable in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
- ConsoleLogger - Interface in org.apache.maven.plugin.surefire.log.api
-
Allows providers to write console messages on the running maven process.
- ConsoleLoggerDecorator - Class in org.apache.maven.plugin.surefire.log.api
-
Decorator around
ConsoleLogger
. - ConsoleLoggerDecorator(Object) - Constructor for class org.apache.maven.plugin.surefire.log.api.ConsoleLoggerDecorator
- ConsoleLoggerUtils - Class in org.apache.maven.plugin.surefire.log.api
- ConsoleLoggerUtils() - Constructor for class org.apache.maven.plugin.surefire.log.api.ConsoleLoggerUtils
- ConsoleOutputCapture - Class in org.apache.maven.surefire.api.report
-
Deals with system.out/err.
- ConsoleOutputCapture() - Constructor for class org.apache.maven.surefire.api.report.ConsoleOutputCapture
- ConsoleOutputCapture.ForwardingPrintStream - Class in org.apache.maven.surefire.api.report
- ConsoleOutputCapture.NullOutputStream - Class in org.apache.maven.surefire.api.report
- ConsoleOutputFileReporter - Class in org.apache.maven.plugin.surefire.report
-
Surefire output consumer proxy that writes test output to a
File
for each test suite. - ConsoleOutputFileReporter(File, String, boolean, Integer, String) - Constructor for class org.apache.maven.plugin.surefire.report.ConsoleOutputFileReporter
- ConsoleOutputReceiverForCurrentThread - Class in org.apache.maven.surefire.api.report
- ConsoleOutputReceiverForCurrentThread() - Constructor for class org.apache.maven.surefire.api.report.ConsoleOutputReceiverForCurrentThread
- consoleOutputReporter - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- consoleOutputReporter - Variable in class org.apache.maven.plugin.surefire.CommonReflector
- consoleOutputReporter - Variable in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- ConsoleOutputReporter - Class in org.apache.maven.surefire.extensions
-
Extension for logger.
- ConsoleOutputReporter() - Constructor for class org.apache.maven.surefire.extensions.ConsoleOutputReporter
- ConsoleOutputReportEventListener - Interface in org.apache.maven.surefire.extensions
-
Extension listener for logger.
- consoleReporter - Variable in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- ConsoleReporter - Class in org.apache.maven.plugin.surefire.report
-
Base class for console reporters.
- ConsoleReporter(ConsoleLogger, boolean, boolean) - Constructor for class org.apache.maven.plugin.surefire.report.ConsoleReporter
- consoleStream - Variable in class org.apache.maven.surefire.junitcore.JUnitCoreWrapper
- ConsoleWarningEvent - Class in org.apache.maven.surefire.api.event
-
The event with a message for console warning level.
- ConsoleWarningEvent(String) - Constructor for class org.apache.maven.surefire.api.event.ConsoleWarningEvent
- consoleWarningLog(String) - Method in interface org.apache.maven.surefire.api.booter.MasterProcessChannelEncoder
-
Warning log.
- consoleWarningLog(String) - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- Constants - Class in org.apache.maven.surefire.api.booter
- Constants() - Constructor for class org.apache.maven.surefire.api.booter.Constants
- constructTestObject(Class<?>) - Method in class org.apache.maven.surefire.common.junit3.JUnit3Reflector
- consumeLine(String, ProcessInfo) - Method in class org.apache.maven.surefire.booter.PpidChecker.ProcessInfoConsumer
- consumer - Variable in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer
- containsAtLeast(int) - Method in class org.apache.maven.surefire.api.util.TestsToRun
- containsAtLeast(Iterator<Class<?>>, int) - Method in class org.apache.maven.surefire.api.util.TestsToRun
- containsClassName(StackTraceElement[], StackTraceFilter) - Static method in class org.apache.maven.surefire.report.SmartStackTraceParser
- containsEscapesIllegalXml10(String) - Static method in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- containsExactly(int) - Method in class org.apache.maven.surefire.api.util.TestsToRun
- ControlByeEvent - Class in org.apache.maven.surefire.api.event
-
The control event of bye.
- ControlByeEvent() - Constructor for class org.apache.maven.surefire.api.event.ControlByeEvent
- controlEventListeners - Variable in class org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessEventNotifier
- Controller(Scheduler) - Constructor for class org.apache.maven.surefire.junitcore.pc.Scheduler.Controller
- ControlNextTestEvent - Class in org.apache.maven.surefire.api.event
-
The control event of requesting a next test.
- ControlNextTestEvent() - Constructor for class org.apache.maven.surefire.api.event.ControlNextTestEvent
- ControlStopOnNextTestEvent - Class in org.apache.maven.surefire.api.event
-
The control event of stopping on next test.
- ControlStopOnNextTestEvent() - Constructor for class org.apache.maven.surefire.api.event.ControlStopOnNextTestEvent
- convert(Object, Class<?>) - Method in class org.apache.maven.surefire.testng.conf.TestNGMapConfigurator
- convertDeprecatedForkMode() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- convertGroupParameters() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- convertIfRunResult(Object) - Method in class org.apache.maven.surefire.booter.SurefireReflector
- convertJarFileResourceToJavaClassName(String) - Static method in class org.apache.maven.plugin.surefire.util.ScannerUtil
- convertJunitCoreParameters() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Converts old JUnit configuration parameters over to new properties based configuration method.
- convertJunitEngineParameters() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- convertListeners(String) - Method in class org.apache.maven.surefire.testng.conf.TestNG513Configurator
- convertListeners(String) - Method in class org.apache.maven.surefire.testng.conf.TestNG5141Configurator
- convertListeners(String) - Method in class org.apache.maven.surefire.testng.conf.TestNG5143Configurator
- convertListeners(String) - Method in class org.apache.maven.surefire.testng.conf.TestNGMapConfigurator
- convertListenersString(String) - Static method in class org.apache.maven.surefire.testng.conf.TestNG513Configurator
- convertReporterConfig(Object) - Method in class org.apache.maven.surefire.testng.conf.TestNG513Configurator
- convertReporterConfig(Object) - Method in class org.apache.maven.surefire.testng.conf.TestNGMapConfigurator
- convertSlashToSystemFileSeparator(String) - Static method in class org.apache.maven.plugin.surefire.util.ScannerUtil
-
Deprecated.
- convertTestNGParameters() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Converts old TestNG configuration parameters over to new properties based configuration method.
- convertToPath(String) - Static method in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- convertValue(String) - Method in class org.apache.maven.surefire.testng.conf.AbstractDirectConfigurator.Setter
- convertWithCoreCount(String) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- copyExisting(Collection<Description>) - Method in class org.apache.maven.surefire.junitcore.pc.SingleThreadScheduler
- copyListenersTo(Notifier) - Method in class org.apache.maven.surefire.common.junit4.Notifier
- copyProperties(Properties, Map<String, String>) - Static method in class org.apache.maven.plugin.surefire.SurefireProperties
- copyPropertiesFrom(Properties) - Method in class org.apache.maven.plugin.surefire.SurefireProperties
- copyTo(Map<Object, Object>) - Method in class org.apache.maven.plugin.surefire.SurefireProperties
- copyTo(Map<Object, Object>) - Method in interface org.apache.maven.surefire.booter.KeyValueSource
- copyTo(Map<Object, Object>) - Method in class org.apache.maven.surefire.booter.PropertiesWrapper
- copyToSystemProperties() - Method in class org.apache.maven.plugin.surefire.SurefireProperties
- COULD_NOT_RUN_DEFAULT_TESTS - Enum constant in enum class org.apache.maven.plugin.surefire.AbstractSurefireMojo.PluginFailureReason
- COULD_NOT_RUN_SPECIFIED_TESTS - Enum constant in enum class org.apache.maven.plugin.surefire.AbstractSurefireMojo.PluginFailureReason
- count - Variable in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.BufferedStream
- countBufferOverflows() - Method in interface org.apache.maven.surefire.api.util.internal.WritableBufferedByteChannel
- countChildren(Runner) - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- countdown - Variable in class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel.EventBindings
- countdown - Variable in class org.apache.maven.surefire.extensions.util.CountdownCloseable
- countDown - Variable in class org.apache.maven.surefire.extensions.util.CountDownLauncher
- countDown() - Method in class org.apache.maven.surefire.extensions.util.CountDownLauncher
- countdownCloseable - Variable in class org.apache.maven.plugin.surefire.extensions.EventConsumerThread
- countdownCloseable - Variable in class org.apache.maven.surefire.extensions.util.LineConsumerThread
- CountdownCloseable - Class in org.apache.maven.surefire.extensions.util
-
Decrements
countdown
and callscloseable
if reached zero. - CountdownCloseable(Closeable, int) - Constructor for class org.apache.maven.surefire.extensions.util.CountdownCloseable
- CountDownLauncher - Class in org.apache.maven.surefire.extensions.util
-
Counts down the calls
CountDownLauncher.countDown()
and the last reaching zero executes theCountDownLauncher.job()
. - CountDownLauncher(int) - Constructor for class org.apache.maven.surefire.extensions.util.CountDownLauncher
- countFinalRunners() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- countParallelEntities(JUnitCoreParameters) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerUtil
- countTestsInRunner(Description) - Static method in class org.apache.maven.surefire.junit4.JUnit4Provider
-
JUnit error: test count includes one test-class as a suite which has filtered out all children.
- createArgsFile(String, List<String>, List<String>, Collection<String>, File, String, boolean, List<String[]>) - Method in class org.apache.maven.plugin.surefire.booterclient.ModularClasspathForkConfiguration
- createBalancer(int) - Static method in class org.apache.maven.surefire.junitcore.pc.BalancerFactory
-
Balancer without fairness.
- createBalancerWithFairness(int) - Static method in class org.apache.maven.surefire.junitcore.pc.BalancerFactory
-
Balancer with fairness.
- createBooterConfiguration(ClassLoader, boolean) - Method in class org.apache.maven.surefire.booter.SurefireReflector
- createCachableShutdownHookThread(TestLessInputStream.TestLessInputStreamBuilder, Shutdown) - Static method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- createClassLoader(boolean, boolean, String) - Method in class org.apache.maven.surefire.booter.Classpath
- createCommandLine(StartupConfiguration, int, File) - Method in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- createCommandLine(StartupConfiguration, int, File) - Method in class org.apache.maven.plugin.surefire.booterclient.ForkConfiguration
- createComputer() - Method in class org.apache.maven.surefire.junitcore.JUnitCoreWrapper
- createConsoleLogger(ConsoleLogger, ClassLoader) - Static method in class org.apache.maven.plugin.surefire.CommonReflector
- createConsoleOutputReceiver() - Method in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
- createConsoleReporter() - Method in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
- createCopyAndReplaceForkNumPlaceholder(SurefireProperties, int) - Static method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- createCustomListeners(String) - Static method in class org.apache.maven.surefire.common.junit4.JUnit4RunListenerFactory
- createDecoder(ForkNodeArguments) - Method in class org.apache.maven.surefire.booter.spi.LegacyMasterProcessChannelProcessorFactory
- createDecoder(ForkNodeArguments) - Method in class org.apache.maven.surefire.booter.spi.SurefireMasterProcessChannelProcessorFactory
- createDecoder(ForkNodeArguments) - Method in interface org.apache.maven.surefire.spi.MasterProcessChannelProcessorFactory
-
Decoder factory method.
- createDescription(String) - Static method in class org.apache.maven.surefire.common.junit4.JUnit4Reflector
- createDescription(String, Annotation...) - Static method in class org.apache.maven.surefire.common.junit4.JUnit4Reflector
- createDirectoryScannerParameters(DirectoryScannerParameters) - Method in class org.apache.maven.surefire.booter.SurefireReflector
- createDumpFile(File, String) - Method in class org.apache.maven.surefire.api.booter.DumpErrorSingleton
- createDumpStreamFile(File, String) - Method in class org.apache.maven.surefire.api.booter.DumpErrorSingleton
- createEncoder(ForkNodeArguments) - Method in class org.apache.maven.surefire.booter.spi.LegacyMasterProcessChannelProcessorFactory
- createEncoder(ForkNodeArguments) - Method in class org.apache.maven.surefire.booter.spi.SurefireMasterProcessChannelProcessorFactory
- createEncoder(ForkNodeArguments) - Method in interface org.apache.maven.surefire.spi.MasterProcessChannelProcessorFactory
-
Encoder factory method.
- createErrorMessage(SurefireReportParameters, RunResult, Exception) - Static method in class org.apache.maven.plugin.surefire.SurefireHelper
- createExitHandler(PpidChecker) - Method in class org.apache.maven.surefire.booter.ForkedBooter
- createFileReporter() - Method in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
- createFileReporterWriter(File, Charset) - Static method in class org.apache.maven.plugin.surefire.report.FileReporter
- createFiles(List) - Static method in class org.apache.maven.surefire.api.testset.TestRequest
- createFinalRunner(List<Runner>) - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- createForcedShutdownTask() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputer
- createForkChannel(ForkNodeArguments) - Method in class org.apache.maven.plugin.surefire.extensions.LegacyForkNodeFactory
- createForkChannel(ForkNodeArguments) - Method in class org.apache.maven.plugin.surefire.extensions.SurefireForkNodeFactory
- createForkChannel(ForkNodeArguments) - Method in interface org.apache.maven.surefire.extensions.ForkNodeFactory
-
Opens and closes the channel.
- createForkConfiguration(Platform, ResolvePathResultWrapper) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- createForkingReporterFactory() - Method in class org.apache.maven.surefire.booter.ForkedBooter
- createForkStarter(ProviderInfo, ForkConfiguration, ClassLoaderConfiguration, RunOrderParameters, ConsoleLogger, DefaultScanResult, TestClassPath, Platform, ResolvePathResultWrapper) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- createGroupMatchingSelector(Map<String, String>) - Static method in class org.apache.maven.surefire.testng.TestNGExecutor
- createIgnored(String) - Static method in class org.apache.maven.surefire.common.junit4.JUnit4Reflector
- createImmediateShutdownHookThread(TestLessInputStream.TestLessInputStreamBuilder, Shutdown) - Static method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- createInfinitePermitsBalancer() - Static method in class org.apache.maven.surefire.junitcore.pc.BalancerFactory
-
Infinite permits.
- createInProcClasspath(Classpath, Set<Artifact>) - Static method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- createInprocessStarter(ProviderInfo, ClassLoaderConfiguration, RunOrderParameters, DefaultScanResult, Platform, TestClassPath) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- createInstance(Map<String, TestSet>, ReporterFactory, boolean, boolean) - Static method in class org.apache.maven.surefire.junitcore.ConcurrentRunListener
-
Deprecated.
- createInstanceFromSuiteMethod(Class<?>) - Static method in class org.apache.maven.surefire.common.junit3.JUnit3Reflector
- createInvokerStrategy(ConsoleLogger) - Static method in class org.apache.maven.surefire.junitcore.pc.SchedulingStrategies
- createJar(List<String>, String, File) - Method in class org.apache.maven.plugin.surefire.booterclient.JarManifestForkConfiguration
-
Create a jar with just a manifest containing a Main-Class entry for BooterConfiguration and a Class-Path entry for all classpath elements.
- createJUnitCore(Notifier, Collection<RunListener>) - Method in class org.apache.maven.surefire.junitcore.JUnitCoreWrapper
- createJUnitOptions() - Method in class org.apache.maven.surefire.testng.TestNGDirectoryTestSuite
- createListener(C) - Method in class org.apache.maven.surefire.extensions.StatelessReporter
-
Creates reporter.
- createListener(File, String, Integer) - Method in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5ConsoleOutputReporter
- createListener(File, String, Integer) - Method in class org.apache.maven.plugin.surefire.extensions.SurefireConsoleOutputReporter
- createListener(File, String, Integer) - Method in class org.apache.maven.surefire.extensions.ConsoleOutputReporter
- createListener(File, String, Charset) - Method in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5StatelessTestsetInfoReporter
- createListener(File, String, Charset) - Method in class org.apache.maven.plugin.surefire.extensions.SurefireStatelessTestsetInfoReporter
- createListener(File, String, Charset) - Method in class org.apache.maven.surefire.extensions.StatelessTestsetInfoReporter
- createListener(PrintStream, PrintStream) - Method in class org.apache.maven.plugin.surefire.extensions.SurefireConsoleOutputReporter
- createListener(PrintStream, PrintStream) - Method in class org.apache.maven.surefire.extensions.ConsoleOutputReporter
- createListener(DefaultStatelessReportMojoConfiguration) - Method in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5Xml30StatelessReporter
- createListener(DefaultStatelessReportMojoConfiguration) - Method in class org.apache.maven.plugin.surefire.extensions.SurefireStatelessReporter
- createListener(ConsoleLogger) - Method in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5StatelessTestsetInfoReporter
- createListener(ConsoleLogger) - Method in class org.apache.maven.plugin.surefire.extensions.SurefireStatelessTestsetInfoReporter
- createListener(ConsoleLogger) - Method in class org.apache.maven.surefire.extensions.StatelessTestsetInfoReporter
- createMaster(ExecutorService, int) - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- createMatchAnyDescriptionFilter(Iterable<Description>) - Static method in class org.apache.maven.surefire.common.junit4.JUnit4ProviderUtil
- createMergedClassLoader() - Method in class org.apache.maven.surefire.booter.AbstractPathConfiguration
- createMergedClassLoader() - Method in class org.apache.maven.surefire.booter.ModularClasspathConfiguration
- createMergedClassLoader(Classpath) - Method in class org.apache.maven.surefire.booter.AbstractPathConfiguration
- createMessageForMissingRunOrder(String) - Static method in class org.apache.maven.surefire.api.util.RunOrder
- createMethodFilter() - Method in class org.apache.maven.surefire.junit4.JUnit4Provider
- createMethodNameFilteringSelector(TestListResolver) - Static method in class org.apache.maven.surefire.testng.TestNGExecutor
- createNextGeneration(ReportEntry) - Method in class org.apache.maven.surefire.api.runorder.RunEntryStatisticsMap
- createNextGenerationFailure(ReportEntry) - Method in class org.apache.maven.surefire.api.runorder.RunEntryStatisticsMap
- createOutErrElements(OutputStreamWriter, XMLWriter, WrappedReportEntry, OutputStream) - Static method in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- createParallelSharedStrategy(ConsoleLogger, ExecutorService) - Static method in class org.apache.maven.surefire.junitcore.pc.SchedulingStrategies
-
The
threadPool
passed to this strategy can be shared in other strategies. - createParallelStrategy(ConsoleLogger, int) - Static method in class org.apache.maven.surefire.junitcore.pc.SchedulingStrategies
- createParallelStrategyUnbounded(ConsoleLogger) - Static method in class org.apache.maven.surefire.junitcore.pc.SchedulingStrategies
- createPingHandler(AtomicBoolean) - Method in class org.apache.maven.surefire.booter.ForkedBooter
- createPingJob(AtomicBoolean, PpidChecker) - Method in class org.apache.maven.surefire.booter.ForkedBooter
- createPingScheduler() - Static method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- createPool(int) - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- createProvider(boolean) - Method in class org.apache.maven.surefire.booter.ProviderFactory
- createProviderConfiguration(RunOrderParameters) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- createProviderInCurrentClassloader() - Method in class org.apache.maven.surefire.booter.ForkedBooter
- createProviders(TestClassPath) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- createReportEntry(Integer, Map<String, String>) - Method in class org.apache.maven.surefire.junitcore.TestSet
-
Deprecated.
- createReportEntry(ReportEntry) - Method in class org.apache.maven.surefire.junitcore.TestMethod
-
Deprecated.
- createReportEntry(TestIdentifier) - Method in class org.apache.maven.surefire.junitplatform.RunListenerAdapter
- createReportEntry(TestIdentifier, TestExecutionResult, Integer) - Method in class org.apache.maven.surefire.junitplatform.RunListenerAdapter
- createReportEntry(TestIdentifier, TestExecutionResult, String, Integer) - Method in class org.apache.maven.surefire.junitplatform.RunListenerAdapter
- createReportEntry(TestIdentifier, TestExecutionResult, Map<String, String>, String, Integer) - Method in class org.apache.maven.surefire.junitplatform.RunListenerAdapter
- createReportEntry(Description) - Method in class org.apache.maven.surefire.common.junit4.JUnit4RunListener
- createReportEntryCompleted(int) - Method in class org.apache.maven.surefire.junitcore.TestSet
-
Deprecated.
- createReportEntryForTestSet(Description, Map<String, String>) - Method in class org.apache.maven.surefire.junitcore.NonConcurrentRunListener
-
Deprecated.
- createReportEntryStarted() - Method in class org.apache.maven.surefire.junitcore.TestSet
-
Deprecated.
- createReporterConfiguration(ReporterConfiguration) - Method in class org.apache.maven.surefire.booter.SurefireReflector
- createReportingReporterFactory(StartupReportConfiguration, ConsoleLogger) - Method in class org.apache.maven.plugin.surefire.CommonReflector
- createRequestAndRun(Filter, Computer, JUnitCoreWrapper.JUnitCore, Class<?>...) - Method in class org.apache.maven.surefire.junitcore.JUnitCoreWrapper
- createRunListener(ReporterFactory) - Method in class org.apache.maven.surefire.junitcore.JUnitCoreProvider
- createRunOrderParameters(RunOrderParameters) - Method in class org.apache.maven.surefire.booter.SurefireReflector
- createScheduler(int) - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- createScheduler(String) - Static method in class org.apache.maven.surefire.booter.ForkedBooter
- createScheduler(Description, ExecutorService, boolean, Balancer) - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- createShutdownHookThread(Iterable<TestProvidingInputStream>, Shutdown) - Static method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- createShutdownTask() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputer
- createSimpleXMLReporter() - Method in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
- createStackTraceWriter(Failure) - Method in class org.apache.maven.surefire.common.junit4.JUnit4RunListener
- createStackTraceWriter(Failure) - Method in class org.apache.maven.surefire.junitcore.JUnitCoreRunListener
- createStartEndReportEntry(Object[]) - Method in class org.apache.maven.surefire.junit.TestListenerInvocationHandler
- createStartupConfiguration(ProviderInfo, boolean, ClassLoaderConfiguration, DefaultScanResult, TestClassPath, Platform, ResolvePathResultWrapper) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- createStartupReportConfiguration(StartupReportConfiguration) - Method in class org.apache.maven.plugin.surefire.CommonReflector
- createStatisticsReporter() - Method in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
- createStoppable(RunListener, int) - Static method in class org.apache.maven.surefire.testng.TestNGExecutor
- createSuite(Collection<Runner>) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- createSurefireBootDirectoryInBuild() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- createSurefireBootDirectoryInTemp() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- createSurefirePropertiesIfFileExists(String, String) - Static method in class org.apache.maven.surefire.booter.ForkedBooter
- createTestArtifactInfo(TestArtifactInfo) - Method in class org.apache.maven.surefire.booter.SurefireReflector
- createTestListResolver(TestListResolver) - Method in class org.apache.maven.surefire.booter.SurefireReflector
- createTestNGReporter(TestReportListener<TestOutputReportEntry>) - Static method in class org.apache.maven.surefire.testng.TestNGProvider
- createTestReportListener() - Method in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
- createTestReportListener() - Method in class org.apache.maven.surefire.api.booter.ForkingReporterFactory
- createTestReportListener() - Method in interface org.apache.maven.surefire.api.report.ReporterFactory
-
Creates a reporter listener.
- createTestRequest(TestRequest) - Method in class org.apache.maven.surefire.booter.SurefireReflector
- createTestsDescription(Iterable<Class<?>>) - Static method in class org.apache.maven.surefire.junit4.JUnit4Provider
- createTestSet(Class<?>, JUnit3Reporter) - Method in class org.apache.maven.surefire.junit.JUnit3Provider
- createTestSet(TypeEncodedValue, boolean, ClassLoader) - Method in class org.apache.maven.surefire.booter.ForkedBooter
- createTestSetReportEntryFinished(Description) - Method in class org.apache.maven.surefire.junitcore.NonConcurrentRunListener
-
Deprecated.
- createTestSetReportEntryStarted(Description) - Method in class org.apache.maven.surefire.junitcore.NonConcurrentRunListener
-
Deprecated.
- createTestSuiteElement(XMLWriter, WrappedReportEntry, TestSetStats) - Method in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- createThreadAttachedTestMethod(ReportEntry) - Method in class org.apache.maven.surefire.junitcore.TestSet
-
Deprecated.
- createTimeoutCheckScheduler() - Static method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- createVersionRange() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- createWindowsCreationDateFormat() - Static method in class org.apache.maven.surefire.booter.PpidChecker
-
The beginning part of Windows WMIC format yyyymmddHHMMSS.xxx
https://technet.microsoft.com/en-us/library/ee198928.aspx
We use UTC time zone which avoids DST changes, see SUREFIRE-1512. - createWriter(File) - Static method in class org.apache.maven.surefire.api.util.internal.DumpFileUtils
- creatingThread - Variable in class org.apache.maven.surefire.api.provider.AbstractProvider
- CURRENT - Static variable in class org.apache.maven.surefire.api.report.ConsoleOutputReceiverForCurrentThread
- currentDecoder - Variable in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.Memento
- currentForkClients - Variable in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- currentTestSetDescription - Variable in class org.apache.maven.surefire.junitcore.NonConcurrentRunListener
-
Deprecated.
- customRunListeners - Variable in class org.apache.maven.surefire.junit4.JUnit4Provider
- customRunListeners - Variable in class org.apache.maven.surefire.junitcore.JUnitCoreProvider
D
- DAEMON_THREAD_FACTORY - Static variable in class org.apache.maven.surefire.junitcore.ConfigurableParallelComputer
-
Deprecated.
- DAEMON_THREAD_FACTORY - Static variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputer
- DAEMON_THREAD_FACTORY - Static variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- DAEMON_THREAD_FACTORY - Static variable in class org.apache.maven.surefire.junitcore.pc.SchedulingStrategies
- DaemonThreadFactory - Class in org.apache.maven.surefire.api.util.internal
-
Creates new daemon Thread.
- DaemonThreadFactory() - Constructor for class org.apache.maven.surefire.api.util.internal.DaemonThreadFactory
- DaemonThreadFactory.NamedThreadFactory - Class in org.apache.maven.surefire.api.util.internal
- data - Variable in class org.apache.maven.surefire.api.booter.Command
- data - Variable in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.Memento
- DATA_BYTE - Enum constant in enum class org.apache.maven.surefire.api.stream.SegmentType
- DATA_INT - Enum constant in enum class org.apache.maven.surefire.api.stream.SegmentType
- DATA_INTEGER - Enum constant in enum class org.apache.maven.surefire.api.stream.SegmentType
- DATA_STRING - Enum constant in enum class org.apache.maven.surefire.api.stream.SegmentType
- DATA_STRING_ARRAY - Enum constant in enum class org.apache.maven.surefire.api.stream.SegmentType
- dataFile - Variable in class org.apache.maven.plugin.surefire.runorder.StatisticsReporter
- dataType - Variable in enum class org.apache.maven.surefire.api.booter.MasterProcessCommand
- debug - Variable in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- debug - Variable in class org.apache.maven.plugin.surefire.booterclient.ForkStarter.ForkedNodeArg
- debug(CharSequence, Throwable) - Method in class org.apache.maven.plugin.surefire.log.PluginConsoleLogger
- debug(String) - Method in interface org.apache.maven.plugin.surefire.log.api.ConsoleLogger
- debug(String) - Method in class org.apache.maven.plugin.surefire.log.api.ConsoleLoggerDecorator
- debug(String) - Method in class org.apache.maven.plugin.surefire.log.api.NullConsoleLogger
- debug(String) - Method in class org.apache.maven.plugin.surefire.log.api.PrintStreamLogger
- debug(String) - Method in class org.apache.maven.plugin.surefire.log.PluginConsoleLogger
- debug(String) - Method in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- debug(String) - Method in class org.apache.maven.surefire.api.booter.ForkingRunListener
- debug(String) - Method in class org.apache.maven.surefire.junitcore.ConcurrentRunListener
-
Deprecated.
- DEBUG_SINK_BUFFER_SIZE - Static variable in class org.apache.maven.surefire.booter.stream.CommandDecoder
- DEBUG_SINK_BUFFER_SIZE - Static variable in class org.apache.maven.surefire.stream.EventDecoder
- debugForkedProcess - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
Attach a debugger to the forked JVM.
- debugForkedProcess - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
Attach a debugger to the forked JVM.
- debugLine - Variable in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- DebugListener() - Constructor for class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.DebugListener
- debugSink - Variable in class org.apache.maven.surefire.booter.stream.CommandDecoder
- debugSink - Variable in class org.apache.maven.surefire.stream.EventDecoder
- debugStream(byte[], int, int) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- debugStream(byte[], int, int) - Method in class org.apache.maven.surefire.booter.stream.CommandDecoder
- debugStream(byte[], int, int) - Method in class org.apache.maven.surefire.stream.EventDecoder
- decode() - Method in interface org.apache.maven.surefire.api.booter.MasterProcessChannelDecoder
-
Reads the bytes from a channel, waiting until the command is read completely or the channel throws
EOFException
. - decode() - Method in class org.apache.maven.surefire.booter.spi.CommandChannelDecoder
- decode(AbstractStreamDecoder.Memento) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- decode(AbstractStreamDecoder.Memento) - Method in class org.apache.maven.surefire.booter.stream.CommandDecoder
- decode(AbstractStreamDecoder.Memento) - Method in class org.apache.maven.surefire.stream.EventDecoder
- decoder - Variable in class org.apache.maven.plugin.surefire.extensions.EventConsumerThread
- decoder - Variable in class org.apache.maven.surefire.booter.CommandReader
- decoder - Variable in class org.apache.maven.surefire.booter.spi.CommandChannelDecoder
- decodeString(CharsetDecoder, ByteBuffer, CharBuffer, int, boolean, int) - Static method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- DEFAULT - Enum constant in enum class org.apache.maven.surefire.api.booter.Shutdown
- DEFAULT - Static variable in class org.apache.maven.surefire.api.util.RunOrder
- DEFAULT_PROVIDER_CLASS - Static variable in class org.apache.maven.plugin.surefire.booterclient.ForkConfiguration
- DEFAULT_STREAM_ENCODING - Static variable in class org.apache.maven.surefire.api.booter.Constants
- DEFAULT_STREAM_ENCODING_BYTES - Static variable in class org.apache.maven.surefire.api.booter.Constants
- DEFAULT_STREAM_ENCODING_BYTES - Static variable in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- DEFAULT_SUREFIRE_SUITE_NAME - Static variable in class org.apache.maven.surefire.testng.TestNGExecutor
-
The default name for a suite launched from the maven surefire plugin
- DEFAULT_SUREFIRE_TEST_NAME - Static variable in class org.apache.maven.surefire.testng.TestNGExecutor
-
The default name for a test launched from the maven surefire plugin
- DEFAULT_SYSTEM_EXIT_TIMEOUT_IN_SECONDS - Static variable in class org.apache.maven.surefire.booter.ForkedBooter
- DEFAULT_THREAD_FACTORY - Static variable in class org.apache.maven.surefire.api.util.internal.DaemonThreadFactory
- defaultClassesDirectory - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- DefaultCommandReader - Class in org.apache.maven.plugin.surefire.booterclient.lazytestprovider
-
Reader stream sends commands to forked jvm std-
input-stream
. - DefaultCommandReader() - Constructor for class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.DefaultCommandReader
- defaultDecoder - Variable in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.Memento
- DefaultDirectoryScanner - Class in org.apache.maven.surefire.api.util
-
Deprecated.
- DefaultDirectoryScanner(File, List<String>, List<String>, List<String>) - Constructor for class org.apache.maven.surefire.api.util.DefaultDirectoryScanner
-
Deprecated.
- DefaultForkConfiguration - Class in org.apache.maven.plugin.surefire.booterclient
-
Basic framework which constructs CLI.
- DefaultForkConfiguration(Classpath, File, String, File, Properties, String, Map<String, String>, String[], boolean, int, boolean, Platform, ConsoleLogger, ForkNodeFactory) - Constructor for class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- defaultReporterFactories - Variable in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- defaultReporterFactory - Variable in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
- DefaultReporterFactory - Class in org.apache.maven.plugin.surefire.report
-
Provides reporting modules on the plugin side.
- DefaultReporterFactory(StartupReportConfiguration, ConsoleLogger) - Constructor for class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
- DefaultReporterFactory(StartupReportConfiguration, ConsoleLogger, Integer) - Constructor for class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
- DefaultReporterFactory.TestResultType - Enum Class in org.apache.maven.plugin.surefire.report
- DefaultRunOrderCalculator - Class in org.apache.maven.surefire.api.util
-
Applies the final runorder of the tests
- DefaultRunOrderCalculator(RunOrderParameters, int) - Constructor for class org.apache.maven.surefire.api.util.DefaultRunOrderCalculator
- DefaultScanResult - Class in org.apache.maven.surefire.api.util
- DefaultScanResult(List<String>) - Constructor for class org.apache.maven.surefire.api.util.DefaultScanResult
- DefaultStatelessReportMojoConfiguration - Class in org.apache.maven.plugin.surefire.extensions
-
Deprecated.
- DefaultStatelessReportMojoConfiguration(File, String, boolean, int, String, Map<String, Deque<WrappedReportEntry>>) - Constructor for class org.apache.maven.plugin.surefire.extensions.DefaultStatelessReportMojoConfiguration
-
Deprecated.
- DELIMITER_LENGTH - Static variable in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- dependenciesToScan - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
List of dependencies to scan for test classes to include in the test run.
- dependenciesToScan - Variable in class org.apache.maven.plugin.surefire.util.DependencyScanner
- DependencyScanner - Class in org.apache.maven.plugin.surefire.util
-
Scans dependencies looking for tests.
- DependencyScanner(List<File>, TestListResolver) - Constructor for class org.apache.maven.plugin.surefire.util.DependencyScanner
- describe() - Method in class org.apache.maven.surefire.common.junit4.MatchDescriptions
- describe() - Method in class org.apache.maven.surefire.common.junit48.AndFilter
- describe() - Method in class org.apache.maven.surefire.common.junit48.CombinedCategoryFilter
- describe() - Method in class org.apache.maven.surefire.common.junit48.InvertedFilter
- describe() - Method in class org.apache.maven.surefire.common.junit48.MethodFilter
- describe() - Method in class org.apache.maven.surefire.common.junit48.OrFilter
- describe() - Method in class org.apache.maven.surefire.common.junit48.RequestedTest
- describe() - Method in class org.apache.maven.surefire.junit4.TestResolverFilter
- describe() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC.SuiteFilter
- describeElapsedTimeout() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputer
- describesNewTestSet(Description) - Method in class org.apache.maven.surefire.junitcore.NonConcurrentRunListener
-
Deprecated.
- describeStopped(boolean) - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputer
- describeStopped(boolean) - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- describeStopped(boolean) - Method in class org.apache.maven.surefire.junitcore.pc.Scheduler
-
Attempts to stop all actively executing tasks and immediately returns a collection of descriptions of those tasks which have started prior to this call.
- describeStopped(boolean) - Method in class org.apache.maven.surefire.junitcore.pc.SingleThreadScheduler
- description - Variable in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- description - Variable in class org.apache.maven.surefire.junitcore.pc.Scheduler
- description - Variable in class org.apache.maven.surefire.junitcore.TestMethod
-
Deprecated.
- description(String, String, boolean) - Static method in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- descriptionsBeforeShutdown - Variable in class org.apache.maven.surefire.junitcore.pc.ShutdownStatus
- deserialize() - Method in class org.apache.maven.surefire.booter.BooterDeserializer
- DeserializedStacktraceWriter - Class in org.apache.maven.plugin.surefire.booterclient.output
-
Represents a deserialize stacktracewriter that has been marshalled across to the plugin from the fork.
- DeserializedStacktraceWriter(String, String, String) - Constructor for class org.apache.maven.plugin.surefire.booterclient.output.DeserializedStacktraceWriter
- destroy() - Method in class org.apache.maven.surefire.junitcore.pc.AbstractThreadPoolStrategy
- destroy() - Method in interface org.apache.maven.surefire.junitcore.pc.Destroyable
- destroy() - Method in class org.apache.maven.surefire.junitcore.pc.InvokerStrategy
- destroy() - Method in class org.apache.maven.surefire.junitcore.pc.Scheduler.Controller
- Destroyable - Interface in org.apache.maven.surefire.junitcore.pc
-
Destroys the embedded thread-pool.
- destroyableCommands - Variable in class org.apache.maven.surefire.booter.PpidChecker
- destroyActiveCommands() - Method in class org.apache.maven.surefire.booter.PpidChecker
- detachFromCurrentThread() - Method in class org.apache.maven.surefire.junitcore.TestMethod
-
Deprecated.
- detailsForThis - Variable in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- determineThreadCounts(long, long, long) - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- DirectConsoleOutput - Class in org.apache.maven.plugin.surefire.report
-
Outputs test system out/system err directly to the console
Just a step on the road to getting the separation of reporting concerns operating properly. - DirectConsoleOutput(PrintStream, PrintStream) - Constructor for class org.apache.maven.plugin.surefire.report.DirectConsoleOutput
- DirectoryScanner - Class in org.apache.maven.plugin.surefire.util
-
Scans directories looking for tests.
- DirectoryScanner - Interface in org.apache.maven.surefire.api.util
-
Deprecated.
- DirectoryScanner(File, TestListResolver) - Constructor for class org.apache.maven.plugin.surefire.util.DirectoryScanner
- directoryScannerParameters - Variable in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- directoryScannerParameters - Variable in class org.apache.maven.surefire.booter.SurefireReflector
- DirectoryScannerParameters - Class in org.apache.maven.surefire.api.testset
- DirectoryScannerParameters(File, List<String>, List<String>, List<String>, String) - Constructor for class org.apache.maven.surefire.api.testset.DirectoryScannerParameters
- DirectoryScannerParameters(File, List<String>, List<String>, List<String>, RunOrder[]) - Constructor for class org.apache.maven.surefire.api.testset.DirectoryScannerParameters
- dirScannerParams - Variable in class org.apache.maven.surefire.booter.ProviderConfiguration
- disable - Variable in class org.apache.maven.surefire.extensions.ConsoleOutputReporter
-
false
by default - disable - Variable in class org.apache.maven.surefire.extensions.StatelessReporter
-
false
by default - disable - Variable in class org.apache.maven.surefire.extensions.StatelessTestsetInfoReporter
- disable() - Method in class org.apache.maven.plugin.surefire.extensions.EventConsumerThread
- disable() - Method in class org.apache.maven.plugin.surefire.extensions.LegacyForkChannel
- disable() - Method in class org.apache.maven.plugin.surefire.extensions.StreamFeeder
- disable() - Method in class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel
- disable() - Method in class org.apache.maven.surefire.extensions.ForkChannel
- disable() - Method in interface org.apache.maven.surefire.extensions.Stoppable
- disable() - Method in class org.apache.maven.surefire.extensions.util.LineConsumerThread
- disable() - Method in class org.apache.maven.surefire.junitcore.pc.SchedulingStrategy
-
Persistently disables this strategy.
- disabled - Variable in class org.apache.maven.plugin.surefire.extensions.EventConsumerThread
- disabled - Variable in class org.apache.maven.plugin.surefire.extensions.StreamFeeder
- disabled - Variable in class org.apache.maven.surefire.extensions.util.LineConsumerThread
- disableXmlReport - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Deprecated.
- discover(LauncherDiscoveryRequest) - Method in class org.apache.maven.surefire.junitplatform.LazyLauncher
- DiscoveredTestMethods() - Constructor for class org.apache.maven.surefire.junit.PojoTestSetExecutor.DiscoveredTestMethods
- discoverTestMethods(Class<?>) - Method in class org.apache.maven.surefire.junit.PojoTestSetExecutor
- doHasNext() - Method in class org.apache.maven.surefire.api.util.CloseableIterator
- doHasNext() - Method in class org.apache.maven.surefire.api.util.TestsToRun.ClassesIterator
- doNext() - Method in class org.apache.maven.surefire.api.util.CloseableIterator
- doNext() - Method in class org.apache.maven.surefire.api.util.TestsToRun.ClassesIterator
- doRemove() - Method in class org.apache.maven.surefire.api.util.CloseableIterator
- doRemove() - Method in class org.apache.maven.surefire.api.util.TestsToRun.ClassesIterator
- drawNumber() - Static method in class org.apache.maven.plugin.surefire.booterclient.ForkNumberBucket
- drawNumberInternal() - Method in class org.apache.maven.plugin.surefire.booterclient.ForkNumberBucket
- DUMP_FILE_DATE - Static variable in class org.apache.maven.plugin.surefire.SurefireHelper
- DUMP_FILE_EXT - Static variable in class org.apache.maven.surefire.api.booter.DumpErrorSingleton
- DUMP_FILE_PREFIX - Static variable in class org.apache.maven.plugin.surefire.SurefireHelper
- DUMP_FILENAME - Static variable in class org.apache.maven.plugin.surefire.SurefireHelper
- DUMP_FILENAME_FORMATTER - Static variable in class org.apache.maven.plugin.surefire.SurefireHelper
- DUMP_FILES_PRINT - Static variable in class org.apache.maven.plugin.surefire.SurefireHelper
- DumpErrorSingleton - Class in org.apache.maven.surefire.api.booter
-
Dumps lost commands and caused exceptions in forked JVM.
- DumpErrorSingleton() - Constructor for class org.apache.maven.surefire.api.booter.DumpErrorSingleton
- dumpException(IOException) - Method in class org.apache.maven.plugin.surefire.report.ConsoleOutputFileReporter
- dumpException(Throwable) - Method in class org.apache.maven.surefire.api.booter.DumpErrorSingleton
- dumpException(Throwable, File) - Static method in class org.apache.maven.surefire.api.util.internal.DumpFileUtils
- dumpException(Throwable, String) - Method in class org.apache.maven.surefire.api.booter.DumpErrorSingleton
- dumpException(Throwable, String, File) - Method in class org.apache.maven.plugin.surefire.booterclient.output.InPluginProcessDumpSingleton
- dumpException(Throwable, String, File) - Static method in class org.apache.maven.surefire.api.util.internal.DumpFileUtils
- dumpException(Throwable, String, File, int) - Method in class org.apache.maven.plugin.surefire.booterclient.output.InPluginProcessDumpSingleton
- dumpFile - Variable in class org.apache.maven.surefire.api.booter.DumpErrorSingleton
- DumpFileUtils - Class in org.apache.maven.surefire.api.util.internal
-
Dumps a text or exception in dump file.
- DumpFileUtils() - Constructor for class org.apache.maven.surefire.api.util.internal.DumpFileUtils
- dumpLogDir - Variable in class org.apache.maven.plugin.surefire.booterclient.ForkStarter.ForkedNodeArg
- DUMPSTREAM_FILE_EXT - Static variable in class org.apache.maven.surefire.api.booter.DumpErrorSingleton
- DUMPSTREAM_FILENAME - Static variable in class org.apache.maven.plugin.surefire.SurefireHelper
- DUMPSTREAM_FILENAME_FORMATTER - Static variable in class org.apache.maven.plugin.surefire.SurefireHelper
- dumpStreamException(Throwable) - Method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter.ForkedNodeArg
- dumpStreamException(Throwable) - Method in class org.apache.maven.surefire.api.booter.DumpErrorSingleton
- dumpStreamException(Throwable) - Method in interface org.apache.maven.surefire.api.fork.ForkNodeArguments
- dumpStreamException(Throwable) - Method in class org.apache.maven.surefire.booter.ForkedNodeArg
- dumpStreamException(Throwable, String) - Method in class org.apache.maven.surefire.api.booter.DumpErrorSingleton
- dumpStreamException(Throwable, String, File) - Method in class org.apache.maven.plugin.surefire.booterclient.output.InPluginProcessDumpSingleton
- dumpStreamException(Throwable, String, File, int) - Method in class org.apache.maven.plugin.surefire.booterclient.output.InPluginProcessDumpSingleton
- dumpStreamFile - Variable in class org.apache.maven.surefire.api.booter.DumpErrorSingleton
- dumpStreamText(String) - Method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter.ForkedNodeArg
- dumpStreamText(String) - Method in class org.apache.maven.surefire.api.booter.DumpErrorSingleton
- dumpStreamText(String) - Method in interface org.apache.maven.surefire.api.fork.ForkNodeArguments
- dumpStreamText(String) - Method in class org.apache.maven.surefire.booter.ForkedNodeArg
- dumpStreamText(String, File) - Method in class org.apache.maven.plugin.surefire.booterclient.output.InPluginProcessDumpSingleton
- dumpStreamText(String, File, int) - Method in class org.apache.maven.plugin.surefire.booterclient.output.InPluginProcessDumpSingleton
- dumpText(String) - Method in class org.apache.maven.surefire.api.booter.DumpErrorSingleton
- dumpText(String, File) - Static method in class org.apache.maven.surefire.api.util.internal.DumpFileUtils
- dumpToLoFile(String) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
- DynamicProviderInfo(String) - Constructor for class org.apache.maven.plugin.surefire.AbstractSurefireMojo.DynamicProviderInfo
E
- effectiveForkCount - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- effectiveIsEnableAssertions() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- elapsed - Variable in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- elapsed - Variable in class org.apache.maven.surefire.api.report.SimpleReportEntry
- elapsedTimeAsString() - Method in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- embeddedChildrenCount - Variable in class org.apache.maven.surefire.junitcore.pc.WrappedRunners
- EMPTY - Static variable in class org.apache.maven.surefire.api.testset.TestListResolver
- EMPTY_CLASS_ARRAY - Static variable in class org.apache.maven.surefire.api.util.ReflectionUtils
- EMPTY_CLASS_ARRAY - Static variable in class org.apache.maven.surefire.common.junit3.JUnit3Reflector
- EMPTY_CLASS_ARRAY - Static variable in class org.apache.maven.surefire.common.junit3.JUnit3TestChecker
- EMPTY_CLASS_ARRAY - Static variable in class org.apache.maven.surefire.junit.TestListenerInvocationHandler
- EMPTY_COMPLETABLE - Static variable in interface org.apache.maven.surefire.extensions.Completable
- EMPTY_OBJECT_ARRAY - Static variable in class org.apache.maven.surefire.api.util.ReflectionUtils
- EMPTY_OBJECT_ARRAY - Static variable in class org.apache.maven.surefire.common.junit3.JUnit3Reflector
- EMPTY_OBJECT_ARRAY - Static variable in class org.apache.maven.surefire.junit.PojoTestSetExecutor
- EMPTY_STRING_ARRAY - Static variable in class org.apache.maven.surefire.api.util.DefaultDirectoryScanner
-
Deprecated.
- EMPTY_STRING_ARRAY - Static variable in class org.apache.maven.surefire.junit.TestListenerInvocationHandler
- EMPTY_URL_ARRAY - Static variable in class org.apache.maven.surefire.booter.IsolatedClassLoader
- emptyClasspath() - Static method in class org.apache.maven.surefire.booter.Classpath
- ENABLE_ASSERTIONS - Static variable in class org.apache.maven.surefire.booter.AbstractPathConfiguration
- enableAssertions - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
By default, Surefire enables JVM assertions for the execution of your test cases.
- enableAssertions - Variable in class org.apache.maven.surefire.booter.AbstractPathConfiguration
-
Whether to enable assertions or not (can be affected by the fork arguments, and the ability to do so based on the JVM).
- enableProcessChecker - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
Since 3.0.0-M4 the process checkers are disabled.
- enableProcessChecker - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
Since 3.0.0-M4 the process checkers are disabled.
- encode(CharsetEncoder, ByteBuffer, E, String...) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamEncoder
- encode(CharsetEncoder, ByteBuffer, E, RunMode, Long, String...) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamEncoder
- encode(CharsetEncoder, ByteBuffer, String, String, String) - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- encode(CharsetEncoder, ByteBuffer, EventChannelEncoder.StackTrace) - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- encode(ForkedProcessEventType, ReportEntry, boolean) - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
-
Used operations:
ForkedProcessEventType.BOOTERCODE_TESTSET_STARTING
,ForkedProcessEventType.BOOTERCODE_TESTSET_COMPLETED
,ForkedProcessEventType.BOOTERCODE_TEST_STARTING
,ForkedProcessEventType.BOOTERCODE_TEST_SUCCEEDED
,ForkedProcessEventType.BOOTERCODE_TEST_FAILED
,ForkedProcessEventType.BOOTERCODE_TEST_ERROR
,ForkedProcessEventType.BOOTERCODE_TEST_SKIPPED
,ForkedProcessEventType.BOOTERCODE_TEST_ASSUMPTIONFAILURE
. - encode(ForkedProcessEventType, ReportEntry, boolean, boolean) - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- encodeCharset(ByteBuffer) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamEncoder
- encodeHeader(ByteBuffer, E) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamEncoder
- encodeHeader(ByteBuffer, E, RunMode, Long) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamEncoder
- encodeInteger(ByteBuffer, Integer) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamEncoder
- encodeMessage(ForkedProcessEventType, String) - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- encodeMessage(ForkedProcessEventType, RunMode, Long, String) - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- encodeOpcode(ForkedProcessEventType, boolean) - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- encodeString(CharsetEncoder, ByteBuffer, String) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamEncoder
- encodeStringData(ByteBuffer, CharsetEncoder, String...) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamEncoder
- encodeSystemProperties(Map<String, String>, RunMode, Long) - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- encoding - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
The character encoding scheme to be applied while generating test report files (see target/surefire-reports/yourTestName.txt).
- encoding - Variable in class org.apache.maven.plugin.failsafe.VerifyMojo
-
Deprecated.since of 2.20.1
- encoding - Variable in class org.apache.maven.plugin.surefire.report.ConsoleOutputFileReporter
- encoding - Variable in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- encoding - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
The character encoding scheme to be applied while generating test report files (see target/surefire-reports/yourTestName.txt).
- encoding - Variable in class org.apache.maven.surefire.extensions.ConsoleOutputReporter
-
The content is encoded UTF-8 by default.
- encoding - Variable in class org.apache.maven.surefire.extensions.StatelessTestsetInfoFileReportEventListener
- encoding - Variable in class org.apache.maven.surefire.extensions.util.LineConsumerThread
- EncodingOutputStream(OutputStream) - Constructor for class org.apache.maven.plugin.surefire.report.StatelessXmlReporter.EncodingOutputStream
- END_ITEM - Static variable in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer
- END_OF_FRAME - Enum constant in enum class org.apache.maven.surefire.api.stream.SegmentType
- END_TEST - Static variable in class org.apache.maven.surefire.junit.TestListenerInvocationHandler
- endOfStreamsCountdown - Variable in class org.apache.maven.surefire.extensions.util.CommandlineExecutor
- endsWithJavaPath(String) - Static method in class org.apache.maven.surefire.booter.SystemUtils
- endTime - Variable in class org.apache.maven.surefire.junitcore.TestMethod
-
Deprecated.
- ensureCapacity(int) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.BufferedStream
- ensureEnableProcessChecker() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- ensureParallelRunningCompatibility() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- ensureThreadCountWithPerThread() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- ensureWorkingDirectoryExists() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- entrySet() - Method in class org.apache.maven.surefire.api.util.internal.ImmutableMap
- enumToByteArray(E) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamEncoder
- enumToByteArray(ForkedProcessEventType) - Method in class org.apache.maven.surefire.booter.stream.EventEncoder
- enumToByteArray(MasterProcessCommand) - Method in class org.apache.maven.surefire.stream.CommandEncoder
- environmentVariables - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Additional environment variables to set on the command line.
- environmentVariables - Variable in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- EOF - Enum constant in enum class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.StreamReadStatus
- equals(Object) - Method in class org.apache.maven.surefire.api.booter.Command
- equals(Object) - Method in class org.apache.maven.surefire.api.report.CategorizedReportEntry
- equals(Object) - Method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- equals(Object) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.Segment
- equals(Object) - Method in class org.apache.maven.surefire.api.suite.RunResult
- equals(Object) - Method in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- equals(Object) - Method in class org.apache.maven.surefire.api.testset.TestListResolver
- equals(Object) - Method in class org.apache.maven.surefire.api.util.internal.ClassMethod
- equals(Object) - Method in class org.apache.maven.surefire.api.util.internal.ImmutableMap.Node
- equals(Object) - Method in class org.apache.maven.surefire.booter.Classpath
- equals(Object) - Method in class org.apache.maven.surefire.booter.TypeEncodedValue
- equals(Object) - Method in class org.apache.maven.surefire.common.junit4.JUnit4Reflector.IgnoredWithUserError
- equals(Object) - Method in class org.apache.maven.surefire.common.junit48.RequestedTest
- equals(Object) - Method in class org.apache.maven.surefire.junit.TestListenerInvocationHandler.FailedTest
- equals(Object) - Method in class org.apache.maven.surefire.junitcore.pc.Scheduler.Controller
- equals(Object) - Method in class org.apache.maven.surefire.report.PojoStackTraceWriter
- equals(RequestedTest) - Method in class org.apache.maven.surefire.common.junit48.RequestedTest
- equalsType(TypeEncodedValue) - Method in class org.apache.maven.surefire.booter.TypeEncodedValue
- equalsValue(TypeEncodedValue) - Method in class org.apache.maven.surefire.booter.TypeEncodedValue
- equalValue(Ignore) - Method in class org.apache.maven.surefire.common.junit4.JUnit4Reflector.IgnoredWithUserError
- err - Variable in class org.apache.maven.plugin.surefire.report.DirectConsoleOutput
- ERR_PROCESS_INFO - Static variable in class org.apache.maven.surefire.booter.ProcessInfo
- error - Enum constant in enum class org.apache.maven.plugin.surefire.report.DefaultReporterFactory.TestResultType
- error(String) - Method in interface org.apache.maven.plugin.surefire.log.api.ConsoleLogger
- error(String) - Method in class org.apache.maven.plugin.surefire.log.api.ConsoleLoggerDecorator
- error(String) - Method in class org.apache.maven.plugin.surefire.log.api.NullConsoleLogger
- error(String) - Method in class org.apache.maven.plugin.surefire.log.api.PrintStreamLogger
- error(String) - Method in class org.apache.maven.plugin.surefire.log.PluginConsoleLogger
- error(String) - Method in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- error(String) - Method in class org.apache.maven.surefire.api.booter.ForkingRunListener
- error(String) - Method in class org.apache.maven.surefire.junitcore.ConcurrentRunListener
-
Deprecated.
- error(String, Throwable) - Method in interface org.apache.maven.plugin.surefire.log.api.ConsoleLogger
-
Simply delegates to
error( toString( t, message ) )
. - error(String, Throwable) - Method in class org.apache.maven.plugin.surefire.log.api.ConsoleLoggerDecorator
- error(String, Throwable) - Method in class org.apache.maven.plugin.surefire.log.api.NullConsoleLogger
- error(String, Throwable) - Method in class org.apache.maven.plugin.surefire.log.api.PrintStreamLogger
- error(String, Throwable) - Method in class org.apache.maven.plugin.surefire.log.PluginConsoleLogger
- error(String, Throwable) - Method in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- error(String, Throwable) - Method in class org.apache.maven.surefire.api.booter.ForkingRunListener
- error(String, Throwable) - Method in class org.apache.maven.surefire.junitcore.ConcurrentRunListener
-
Deprecated.
- error(Throwable) - Method in interface org.apache.maven.plugin.surefire.log.api.ConsoleLogger
-
Simply delegates to method
error(null, Throwable)
. - error(Throwable) - Method in class org.apache.maven.plugin.surefire.log.api.ConsoleLoggerDecorator
- error(Throwable) - Method in class org.apache.maven.plugin.surefire.log.api.NullConsoleLogger
- error(Throwable) - Method in class org.apache.maven.plugin.surefire.log.api.PrintStreamLogger
- error(Throwable) - Method in class org.apache.maven.plugin.surefire.log.PluginConsoleLogger
- error(Throwable) - Method in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- error(Throwable) - Method in class org.apache.maven.surefire.api.booter.ForkingRunListener
- error(Throwable) - Method in class org.apache.maven.surefire.junitcore.ConcurrentRunListener
-
Deprecated.
- error(StackTraceWriter, boolean, ForkedProcessEventType, boolean) - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- ERROR - Enum constant in enum class org.apache.maven.plugin.surefire.report.ReportEntryType
- errorCode(RunResult, String, boolean) - Static method in class org.apache.maven.surefire.api.suite.RunResult
- errorInFork - Variable in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
- ErrorListener() - Constructor for class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.ErrorListener
- errors - Variable in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.Pumper
- errors - Variable in class org.apache.maven.plugin.surefire.report.TestSetStats
- errors - Variable in class org.apache.maven.surefire.api.suite.RunResult
- errors - Variable in class org.apache.maven.surefire.report.RunStatistics
- ERRORS - Static variable in class org.apache.maven.plugin.surefire.report.TestSetStats
- errorTests - Variable in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
- errStreamLock - Variable in class org.apache.maven.plugin.surefire.booterclient.output.NativeStdErrStreamConsumer
- escapeToPlatformPath(String) - Static method in class org.apache.maven.plugin.surefire.SurefireHelper
-
Escape file path for Windows when the path is too long; otherwise returns
path
. - escapeUri(String, Charset) - Static method in class org.apache.maven.plugin.surefire.booterclient.JarManifestForkConfiguration
- escapeXml(String, boolean) - Static method in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
-
escape for XML 1.0
- estimateBufferLength(int, RunMode, CharsetEncoder, int, int, String...) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamEncoder
- estimateConcurrency(JUnitCoreParameters, RunnerCounter) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerUtil
- Event - Class in org.apache.maven.surefire.api.event
-
Super type of events.
- Event(ForkedProcessEventType) - Constructor for class org.apache.maven.surefire.api.event.Event
- EVENT_TEST_CONTROL - Static variable in class org.apache.maven.surefire.stream.EventDecoder
- EVENT_TYPES - Static variable in class org.apache.maven.surefire.stream.EventDecoder
- EVENT_WITH_ERROR_TRACE - Static variable in class org.apache.maven.surefire.stream.EventDecoder
- EVENT_WITH_ONE_STRING - Static variable in class org.apache.maven.surefire.stream.EventDecoder
- EVENT_WITH_RUNMODE_TID_AND_ONE_STRING - Static variable in class org.apache.maven.surefire.stream.EventDecoder
- EVENT_WITH_RUNMODE_TID_AND_TWO_STRINGS - Static variable in class org.apache.maven.surefire.stream.EventDecoder
- EVENT_WITHOUT_DATA - Static variable in class org.apache.maven.surefire.stream.EventDecoder
- eventBindings - Variable in class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel
- EventBindings(EventHandler<Event>, CountdownCloseable) - Constructor for class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel.EventBindings
- eventChannel - Variable in class org.apache.maven.surefire.api.booter.ForkingReporterFactory
- eventChannel - Variable in class org.apache.maven.surefire.booter.CommandReader.ClassesIterable
- eventChannel - Variable in class org.apache.maven.surefire.booter.CommandReader.ClassesIterator
- eventChannel - Variable in class org.apache.maven.surefire.booter.ForkedBooter
- eventChannel - Variable in class org.apache.maven.surefire.booter.LazyTestsToRun
- EventChannelEncoder - Class in org.apache.maven.surefire.booter.spi
-
magic number : opcode : run mode [: opcode specific data]*
- EventChannelEncoder(WritableBufferedByteChannel) - Constructor for class org.apache.maven.surefire.booter.spi.EventChannelEncoder
-
The encoder for events.
- EventChannelEncoder.StackTrace - Class in org.apache.maven.surefire.booter.spi
- EventConsumerThread - Class in org.apache.maven.plugin.surefire.extensions
- EventConsumerThread(String, ReadableByteChannel, EventHandler<Event>, CountdownCloseable, ForkNodeArguments) - Constructor for class org.apache.maven.plugin.surefire.extensions.EventConsumerThread
- EventDecoder - Class in org.apache.maven.surefire.stream
- EventDecoder(ReadableByteChannel, ForkNodeArguments) - Constructor for class org.apache.maven.surefire.stream.EventDecoder
- EventEncoder - Class in org.apache.maven.surefire.booter.stream
- EventEncoder(WritableBufferedByteChannel) - Constructor for class org.apache.maven.surefire.booter.stream.EventEncoder
- eventHandler - Variable in class org.apache.maven.plugin.surefire.extensions.EventConsumerThread
- eventHandler - Variable in class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel.EventBindings
- eventHandler - Variable in class org.apache.maven.surefire.extensions.util.LineConsumerThread
- EventHandler<T> - Interface in org.apache.maven.surefire.extensions
-
Handler of events.
- eventHandlerBindings - Variable in class org.apache.maven.plugin.surefire.extensions.LegacyForkChannel
- eventHandlerBindings - Variable in class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel
- EVENTS_BINARY_DUMP_FILENAME_FORMATTER - Static variable in class org.apache.maven.plugin.surefire.SurefireHelper
- eventType - Variable in class org.apache.maven.surefire.api.event.Event
- examineNext(boolean) - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder.CIt
- exception - Variable in class org.apache.maven.plugin.surefire.extensions.StreamFeeder
- EXCLUDE_JUNIT5_ENGINES_PROP - Static variable in class org.apache.maven.surefire.api.booter.ProviderParameterNames
- excludedEnvironmentVariables - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
You can selectively exclude individual environment variables by enumerating their keys.
- excludedEnvironmentVariables - Variable in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- excludedEnvironmentVariables - Variable in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.Commandline
- excludedEnvironmentVariables - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
You can selectively exclude individual environment variables by enumerating their keys.
- excludedFilters - Variable in class org.apache.maven.surefire.common.junit48.CombinedCategoryFilter
- excludedGroups - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
(TestNG/JUnit47 provider with JUnit4.8+ only and JUnit5+ provider since 2.22.0) Excluded groups/categories/tags.
- excludedPatterns - Variable in class org.apache.maven.surefire.api.testset.TestListResolver
- excludeJUnit5Engines - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
Provide the ID/s of an JUnit engine to be excluded in the test run.
- excludeJUnit5Engines - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
Provide the ID/s of an JUnit engine to be excluded in the test run.
- excludes - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
A list of <exclude> elements specifying the tests (by pattern) that should be excluded in testing.
- excludes - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
A list of <exclude> elements specifying the tests (by pattern) that should be excluded in testing.
- excludes - Variable in class org.apache.maven.surefire.api.testset.DirectoryScannerParameters
-
Deprecated.
- excludes - Variable in class org.apache.maven.surefire.api.util.DefaultDirectoryScanner
-
Deprecated.
- EXCLUDES_PROPERTY_PREFIX - Static variable in class org.apache.maven.surefire.booter.BooterConstants
- excludesFile - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
A file containing exclude patterns, each in a next line.
- excludesFile - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
A file containing exclude patterns.
- execute() - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
- execute() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- execute() - Method in class org.apache.maven.surefire.booter.ForkedBooter
- execute() - Method in class org.apache.maven.surefire.extensions.util.CommandlineExecutor
- execute(Class<?>, ClassLoader) - Method in class org.apache.maven.surefire.junit.JUnitTestSetExecutor
- execute(Class<?>, ClassLoader) - Method in class org.apache.maven.surefire.junit.PojoTestSetExecutor
- execute(Class<?>, ClassLoader) - Method in interface org.apache.maven.surefire.junit.SurefireTestSetExecutor
- execute(Class<?>, Notifier, Filter) - Static method in class org.apache.maven.surefire.junit4.JUnit4Provider
- execute(String...) - Method in class org.apache.maven.surefire.booter.PpidChecker.ProcessInfoConsumer
- execute(TestsToRun, boolean, Collection<RunListener>, Filter) - Method in class org.apache.maven.surefire.junitcore.JUnitCoreWrapper
- execute(TestsToRun, Collection<RunListener>, Filter) - Method in class org.apache.maven.surefire.junitcore.JUnitCoreWrapper
- execute(TestsToRun, RunListenerAdapter) - Method in class org.apache.maven.surefire.junitplatform.JUnitPlatformProvider
- execute(TestsToRun, TestNGReporter) - Method in class org.apache.maven.surefire.testng.TestNGDirectoryTestSuite
- execute(TestsToRun, Filter) - Method in class org.apache.maven.surefire.junitcore.JUnitCoreWrapper
- execute(TestNGReporter) - Method in class org.apache.maven.surefire.testng.TestNGXmlTestSuite
- execute(LauncherDiscoveryRequest, TestExecutionListener...) - Method in class org.apache.maven.surefire.junitplatform.LazyLauncher
- execute(TestPlan, TestExecutionListener...) - Method in class org.apache.maven.surefire.junitplatform.LazyLauncher
- executeAfterPreconditionsChecked(DefaultScanResult, Platform) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- executeEager(TestsToRun, Filter, Collection<RunListener>) - Method in class org.apache.maven.surefire.junitcore.JUnitCoreWrapper
- executeLazy(TestsToRun, boolean, Filter, Collection<RunListener>) - Method in class org.apache.maven.surefire.junitcore.JUnitCoreWrapper
- executeLazy(TestsToRun, TestNGReporter) - Method in class org.apache.maven.surefire.testng.TestNGDirectoryTestSuite
- executeMulti(TestsToRun, TestNGReporter) - Method in class org.apache.maven.surefire.testng.TestNGDirectoryTestSuite
- executeProvider(ProviderInfo, DefaultScanResult, TestClassPath, Platform, ResolvePathResultWrapper) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- executeSingleClass(TestNGReporter, Class<?>) - Method in class org.apache.maven.surefire.testng.TestNGDirectoryTestSuite
- executeTestMethod(Class<?>, Method, long, PojoTestSetExecutor.DiscoveredTestMethods) - Method in class org.apache.maven.surefire.junit.PojoTestSetExecutor
- executeTestSet(Class<?>, RunListener, Notifier, RunModeSetter) - Method in class org.apache.maven.surefire.junit4.JUnit4Provider
- executeTestSet(Class<?>, SurefireTestSetExecutor, JUnit3Reporter, Map<String, String>) - Method in class org.apache.maven.surefire.junit.JUnit3Provider
- executeWithRerun(Class<?>, Notifier, RunModeSetter) - Method in class org.apache.maven.surefire.junit4.JUnit4Provider
- EXECUTION_EXCEPTION - Static variable in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- executionFinished(TestIdentifier, TestExecutionResult) - Method in class org.apache.maven.surefire.junitplatform.RunListenerAdapter
- executionSkipped(TestIdentifier, String) - Method in class org.apache.maven.surefire.junitplatform.RunListenerAdapter
- executionStarted(TestIdentifier) - Method in class org.apache.maven.surefire.junitplatform.RunListenerAdapter
- ExecutionStatus - Enum Class in org.apache.maven.surefire.junitcore.pc
-
Status of
ParallelComputer runtime
.
Used together with shutdown hook. - ExecutionStatus() - Constructor for enum class org.apache.maven.surefire.junitcore.pc.ExecutionStatus
- existing - Variable in class org.apache.maven.plugin.surefire.runorder.StatisticsReporter
- existsModuleDescriptor(ResolvePathResultWrapper) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- existsSummary() - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
- existsSummaryFile() - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
- existsSummaryFiles() - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
- EXIT - Enum constant in enum class org.apache.maven.surefire.api.booter.Shutdown
- exit1() - Method in class org.apache.maven.surefire.booter.ForkedBooter
- exitBarrier - Variable in class org.apache.maven.surefire.booter.ForkedBooter
- exitByConfiguration() - Method in class org.apache.maven.surefire.booter.CommandReader.CommandRunnable
- exitErrorEventListener - Variable in class org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessEventNotifier
- ExitErrorEventListener() - Constructor for class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.ExitErrorEventListener
- ext - Variable in class org.apache.maven.plugin.surefire.util.FileScanner
- extendJvmArgLine(String) - Method in class org.apache.maven.plugin.surefire.booterclient.AbstractClasspathForkConfiguration
- extendJvmArgLine(String) - Method in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- extractClassName(String) - Static method in class org.apache.maven.surefire.api.util.internal.TestClassMethodNameUtils
- extractMethodName(String) - Static method in class org.apache.maven.surefire.api.util.internal.TestClassMethodNameUtils
- extractSessionId(URI) - Static method in class org.apache.maven.surefire.booter.spi.SurefireMasterProcessChannelProcessorFactory
- extractVerboseLevel(Map<String, String>) - Static method in class org.apache.maven.surefire.testng.TestNGExecutor
- extraEscapeAttribute(String) - Static method in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
-
Handle stuff that may pop up in java that is not legal in xml.
- extraEscapeElementValue(String, OutputStreamWriter, XMLWriter, OutputStream) - Static method in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
-
Writes escaped string or the message within CDATA if all characters are legal.
F
- FAIL_FAST_COUNT - Static variable in class org.apache.maven.surefire.booter.BooterConstants
- FAILEDFIRST - Static variable in class org.apache.maven.surefire.api.util.RunOrder
- FailedTest(Object, Thread) - Constructor for class org.apache.maven.surefire.junit.TestListenerInvocationHandler.FailedTest
- failedTests - Variable in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
- failedTestsSet - Variable in class org.apache.maven.surefire.junit.TestListenerInvocationHandler
- failFast - Variable in class org.apache.maven.surefire.common.junit4.Notifier
- FailFastEventsSingleton - Class in org.apache.maven.surefire.testng.utils
-
Stores and retrieves atomic events used by
FailFastNotifier
and TestNG provider. - FailFastEventsSingleton() - Constructor for class org.apache.maven.surefire.testng.utils.FailFastEventsSingleton
- FailFastListener - Class in org.apache.maven.surefire.testng.utils
-
Sends an even in
FailFastEventsSingleton
that failure has appeared. - FailFastListener(Stoppable) - Constructor for class org.apache.maven.surefire.testng.utils.FailFastListener
- FailFastNotifier - Class in org.apache.maven.surefire.testng.utils
-
Notifies TestNG core skipping remaining tests after first failure has appeared.
- FailFastNotifier() - Constructor for class org.apache.maven.surefire.testng.utils.FailFastNotifier
- failIfNoSpecifiedTests - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
Set this to "true" to cause a failure if none of the tests specified in -Dtest=...
- failIfNoSpecifiedTests - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
Set this to "true" to cause a failure if none of the tests specified in -Dtest=...
- failIfNoTests - Variable in class org.apache.maven.plugin.failsafe.VerifyMojo
-
Set this to "true" to cause a failure if there are no tests to run.
- failIfNoTests - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Set this to "true" to cause a failure if there are no tests to run.
- failIfNoTests(SurefireReportParameters) - Static method in class org.apache.maven.plugin.surefire.SurefireHelper
- FAILIFNOTESTS - Static variable in class org.apache.maven.surefire.booter.BooterConstants
- failOnFlakeCount - Variable in class org.apache.maven.plugin.failsafe.VerifyMojo
-
Set this to a value greater than 0 to fail the whole test set if the cumulative number of flakes reaches this threshold.
- failOnFlakeCount - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
Set this to a value greater than 0 to fail the whole test set if the cumulative number of flakes reaches this threshold.
- FAILSAFE_IN_PROGRESS_CONTEXT_KEY - Static variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- FAILSAFE_SUMMARY_XML_SCHEMA_LOCATION - Static variable in class org.apache.maven.plugin.failsafe.util.FailsafeSummaryXmlUtils
- FAILSAFE_SUMMARY_XML_TEMPLATE - Static variable in class org.apache.maven.plugin.failsafe.util.FailsafeSummaryXmlUtils
- FailsafeSummaryXmlUtils - Class in org.apache.maven.plugin.failsafe.util
- FailsafeSummaryXmlUtils() - Constructor for class org.apache.maven.plugin.failsafe.util.FailsafeSummaryXmlUtils
- failure - Enum constant in enum class org.apache.maven.plugin.surefire.report.DefaultReporterFactory.TestResultType
- failure - Variable in class org.apache.maven.surefire.api.suite.RunResult
- failure(String) - Method in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
- failure(RunResult, Exception) - Static method in class org.apache.maven.surefire.api.suite.RunResult
- FAILURE - Enum constant in enum class org.apache.maven.plugin.surefire.log.api.Level
-
defaults to bold, green
- FAILURE - Enum constant in enum class org.apache.maven.plugin.surefire.report.ReportEntryType
- FAILURE - Static variable in class org.apache.maven.surefire.api.suite.RunResult
- FAILURE_MARKER - Static variable in class org.apache.maven.plugin.surefire.report.TestSetStats
- failureFlag - Variable in class org.apache.maven.surefire.common.junit4.JUnit4RunListener
-
This flag is set after a failure has occurred so that a
RunListener.testSucceeded(org.apache.maven.surefire.api.report.ReportEntry)
event is not fired. - failures - Variable in class org.apache.maven.plugin.surefire.report.TestSetStats
- failures - Variable in class org.apache.maven.surefire.api.suite.RunResult
- failures - Variable in class org.apache.maven.surefire.junitplatform.RunListenerAdapter
- failures - Variable in class org.apache.maven.surefire.report.RunStatistics
- FAILURES - Static variable in class org.apache.maven.plugin.surefire.report.TestSetStats
- fClasses - Variable in class org.apache.maven.surefire.junitcore.ConfigurableParallelComputer
-
Deprecated.
- fetchCache() - Method in class org.apache.maven.surefire.api.testset.ResolvedTest.MethodMatcher
-
Deprecated.
- file - Variable in class org.apache.maven.plugin.surefire.report.Utf8RecodingDeferredFileOutputStream
- fileOutputStream - Variable in class org.apache.maven.plugin.surefire.report.ConsoleOutputFileReporter
- fileReporter - Variable in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- FileReporter - Class in org.apache.maven.plugin.surefire.report
-
Base class for file reporters.
- FileReporter(File, String, Charset, boolean, boolean, boolean) - Constructor for class org.apache.maven.plugin.surefire.report.FileReporter
- FileReporterUtils - Class in org.apache.maven.plugin.surefire.report
-
Utils class for file-based reporters
- FileReporterUtils() - Constructor for class org.apache.maven.plugin.surefire.report.FileReporterUtils
- FileScanner - Class in org.apache.maven.plugin.surefire.util
- FileScanner(File, String) - Constructor for class org.apache.maven.plugin.surefire.util.FileScanner
- FILESYSTEM - Static variable in class org.apache.maven.surefire.api.util.RunOrder
- fillTestCountMap(Description) - Method in class org.apache.maven.surefire.junitcore.JUnitCoreRunListener
- filter - Variable in class org.apache.maven.plugin.surefire.SurefireDependencyResolver.RuntimeArtifactFilter
- filter - Variable in class org.apache.maven.plugin.surefire.util.DependencyScanner
- filter - Variable in class org.apache.maven.plugin.surefire.util.DirectoryScanner
- filter - Variable in class org.apache.maven.surefire.common.junit48.InvertedFilter
- filter(List<Artifact>, List<String>) - Static method in class org.apache.maven.plugin.surefire.util.DependencyScanner
- filterArtifacts(Set<Artifact>, ArtifactFilter) - Static method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Return a new set containing only the artifacts accepted by the given filter.
- filteredRunner - Variable in class org.apache.maven.surefire.junitcore.FilteringRequest
- filterForSuite(Map<String, String>) - Method in class org.apache.maven.surefire.testng.conf.AbstractDirectConfigurator
- FilteringRequest - Class in org.apache.maven.surefire.junitcore
-
Moved nested class from
JUnitCoreWrapper
. - FilteringRequest(Request, Filter) - Constructor for class org.apache.maven.surefire.junitcore.FilteringRequest
- filterNulls(List<String>) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- filters - Variable in class org.apache.maven.surefire.common.junit4.MatchDescriptions
- filters - Variable in class org.apache.maven.surefire.common.junit48.AndFilter
- filters - Variable in class org.apache.maven.surefire.common.junit48.OrFilter
- filters - Variable in class org.apache.maven.surefire.junitplatform.JUnitPlatformProvider
- FinalEvent() - Constructor for class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.FinalEvent
- findAnnotation(Class<?>, Class<T>) - Static method in class org.apache.maven.surefire.testng.TestNGExecutor
- findByName(String, ProviderInfo...) - Method in class org.apache.maven.surefire.providerapi.ProviderDetector
- findClass(String) - Static method in class org.apache.maven.surefire.booter.LazyTestsToRun
- findJUnitRunWithAnnotation() - Static method in class org.apache.maven.surefire.testng.TestNGDirectoryTestSuite
- findJUnitTestAnnotation() - Static method in class org.apache.maven.surefire.testng.TestNGDirectoryTestSuite
- findJUnitTestClass() - Static method in class org.apache.maven.surefire.testng.TestNGDirectoryTestSuite
- findLeastBusySlot() - Method in class org.apache.maven.surefire.api.runorder.ThreadedExecutionScheduler
- findModuleDescriptor(File) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- findModuleDescriptor(File, File, boolean) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- findOrCreate(ReportEntry) - Method in class org.apache.maven.surefire.api.runorder.RunEntryStatisticsMap
- findStartClass(StartupConfiguration) - Static method in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- findTestMetadata(Class<?>) - Static method in class org.apache.maven.surefire.testng.TestNGExecutor
- findTopmostWithClass(Throwable, StackTraceFilter) - Static method in class org.apache.maven.surefire.report.SmartStackTraceParser
- finishCurrentIteration - Variable in class org.apache.maven.surefire.api.util.CloseableIterator
- finished - Variable in class org.apache.maven.surefire.api.util.TestsToRun
- finished - Variable in class org.apache.maven.surefire.junitcore.pc.Scheduler
- finished() - Method in class org.apache.maven.surefire.junitcore.AsynchronousRunner
-
Deprecated.
- finished() - Method in class org.apache.maven.surefire.junitcore.pc.InvokerStrategy
- finished() - Method in class org.apache.maven.surefire.junitcore.pc.NonSharedThreadPoolStrategy
- finished() - Method in class org.apache.maven.surefire.junitcore.pc.Scheduler
- finished() - Method in class org.apache.maven.surefire.junitcore.pc.SchedulingStrategy
-
Waiting for scheduled tasks to finish.
- finished() - Method in class org.apache.maven.surefire.junitcore.pc.SharedThreadPoolStrategy
- finished() - Method in class org.apache.maven.surefire.junitcore.SynchronousRunner
-
Deprecated.
- FINISHED - Enum constant in enum class org.apache.maven.surefire.junitcore.pc.ExecutionStatus
- finishLastTestSetIfNecessary(Description) - Method in class org.apache.maven.surefire.junitcore.NonConcurrentRunListener
-
Deprecated.
- finishTest(WrappedReportEntry) - Method in class org.apache.maven.plugin.surefire.report.TestSetStats
- finishTestSuite(RunListener) - Method in class org.apache.maven.surefire.testng.TestSuite
- fireStopEvent() - Method in class org.apache.maven.surefire.common.junit4.Notifier
-
Fire stop even to plugin process and/or call
RunNotifier.pleaseStop()
. - fireStopEvent() - Method in interface org.apache.maven.surefire.testng.utils.Stoppable
-
Delegates this call to
RunListener.testExecutionSkippedByUser()
. - fireTestFailure(Failure) - Method in class org.apache.maven.surefire.common.junit4.Notifier
- fireTestStarted(Description) - Method in class org.apache.maven.surefire.common.junit4.Notifier
- first - Variable in class org.apache.maven.surefire.api.util.internal.ImmutableMap
- fixedPool - Variable in class org.apache.maven.surefire.junitcore.ConfigurableParallelComputer
-
Deprecated.
- flake - Enum constant in enum class org.apache.maven.plugin.surefire.report.DefaultReporterFactory.TestResultType
- flakes - Variable in class org.apache.maven.surefire.api.suite.RunResult
- flakes - Variable in class org.apache.maven.surefire.report.RunStatistics
- flakyTests - Variable in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
- flakyXmlTag - Variable in enum class org.apache.maven.plugin.surefire.report.ReportEntryType
- flush() - Method in class org.apache.maven.surefire.api.report.ConsoleOutputCapture.ForwardingPrintStream
- FLUSH_PERIOD_MILLIS - Static variable in class org.apache.maven.surefire.booter.spi.LegacyMasterProcessChannelProcessorFactory
- FLUSH_PERIOD_MILLIS - Static variable in class org.apache.maven.surefire.booter.spi.SurefireMasterProcessChannelProcessorFactory
- flusher - Variable in class org.apache.maven.surefire.booter.spi.AbstractMasterProcessChannelProcessorFactory
- flushEventChannelOnExit() - Method in class org.apache.maven.surefire.booter.ForkedBooter
-
Necessary for the Surefire817SystemExitIT.
- flushImpl() - Method in class org.apache.maven.surefire.api.util.internal.AbstractNoninterruptibleWritableChannel
- fMethods - Variable in class org.apache.maven.surefire.junitcore.ConfigurableParallelComputer
-
Deprecated.
- focusInsideClass(StackTraceElement[], StackTraceFilter) - Static method in class org.apache.maven.surefire.report.SmartStackTraceParser
- focusOnClass(StackTraceElement[], Class<?>) - Static method in class org.apache.maven.surefire.report.SmartStackTraceParser
- forcedShutdownStatus - Variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputer
- fork(Object, PropertiesWrapper, ForkClient, SurefireProperties, int, AbstractCommandReader, ForkNodeFactory, boolean) - Method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- FORK_ALWAYS - Static variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- FORK_NEVER - Static variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- FORK_NODE_CONNECTION_STRING - Static variable in class org.apache.maven.surefire.booter.BooterConstants
- FORK_NUMBER - Static variable in class org.apache.maven.surefire.booter.BooterConstants
- FORK_NUMBER_PLACEHOLDER - Static variable in class org.apache.maven.plugin.surefire.SurefireHelper
-
The placeholder that is replaced by the executing fork's running number.
- FORK_ONCE - Static variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- FORK_PERTHREAD - Static variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- ForkChannel - Class in org.apache.maven.surefire.extensions
-
It's a session object used only by a particular Thread in ForkStarter and communicates with a dedicated forked JVM.
- ForkChannel(ForkNodeArguments) - Constructor for class org.apache.maven.surefire.extensions.ForkChannel
- forkChannelId - Variable in class org.apache.maven.plugin.surefire.booterclient.ForkStarter.ForkedNodeArg
- forkChannelId - Variable in class org.apache.maven.surefire.booter.ForkedNodeArg
- ForkClient - Class in org.apache.maven.plugin.surefire.booterclient.output
-
Knows how to reconstruct *all* the state transmitted over stdout by the forked process.
- ForkClient(DefaultReporterFactory, NotifiableTestStream, int) - Constructor for class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
- ForkClient.AcquireNextTestListener - Class in org.apache.maven.plugin.surefire.booterclient.output
- ForkClient.ByeListener - Class in org.apache.maven.plugin.surefire.booterclient.output
- ForkClient.ConsoleListener - Class in org.apache.maven.plugin.surefire.booterclient.output
- ForkClient.DebugListener - Class in org.apache.maven.plugin.surefire.booterclient.output
- ForkClient.ErrorListener - Class in org.apache.maven.plugin.surefire.booterclient.output
- ForkClient.ExitErrorEventListener - Class in org.apache.maven.plugin.surefire.booterclient.output
- ForkClient.StdErrListener - Class in org.apache.maven.plugin.surefire.booterclient.output
- ForkClient.StdOutListener - Class in org.apache.maven.plugin.surefire.booterclient.output
- ForkClient.SystemPropertiesListener - Class in org.apache.maven.plugin.surefire.booterclient.output
- ForkClient.TestAssumptionFailureListener - Class in org.apache.maven.plugin.surefire.booterclient.output
- ForkClient.TestErrorListener - Class in org.apache.maven.plugin.surefire.booterclient.output
- ForkClient.TestFailedListener - Class in org.apache.maven.plugin.surefire.booterclient.output
- ForkClient.TestSetCompletedListener - Class in org.apache.maven.plugin.surefire.booterclient.output
- ForkClient.TestSetStartingListener - Class in org.apache.maven.plugin.surefire.booterclient.output
- ForkClient.TestSkippedListener - Class in org.apache.maven.plugin.surefire.booterclient.output
- ForkClient.TestStartingListener - Class in org.apache.maven.plugin.surefire.booterclient.output
- ForkClient.TestSucceededListener - Class in org.apache.maven.plugin.surefire.booterclient.output
- ForkClient.WarningListener - Class in org.apache.maven.plugin.surefire.booterclient.output
- forkConfiguration - Variable in class org.apache.maven.plugin.surefire.booterclient.BooterSerializer
- forkConfiguration - Variable in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- ForkConfiguration - Class in org.apache.maven.plugin.surefire.booterclient
-
Configuration for forking tests.
- ForkConfiguration() - Constructor for class org.apache.maven.plugin.surefire.booterclient.ForkConfiguration
- forkCount - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Option to specify the number of VMs to fork in parallel in order to execute the tests.
- forkCount - Variable in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- FORKED_JVM_DAEMON_THREAD_FACTORY - Static variable in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- ForkedBooter - Class in org.apache.maven.surefire.booter
-
The part of the booter that is unique to a forked vm.
- ForkedBooter() - Constructor for class org.apache.maven.surefire.booter.ForkedBooter
- ForkedBooter.PingScheduler - Class in org.apache.maven.surefire.booter
- ForkedNodeArg - Class in org.apache.maven.surefire.booter
- ForkedNodeArg(boolean, int, File, String) - Constructor for class org.apache.maven.plugin.surefire.booterclient.ForkStarter.ForkedNodeArg
- ForkedNodeArg(int, boolean) - Constructor for class org.apache.maven.surefire.booter.ForkedNodeArg
- ForkedProcessEventListener - Interface in org.apache.maven.plugin.surefire.booterclient.output
- ForkedProcessEventNotifier - Class in org.apache.maven.plugin.surefire.booterclient.output
-
magic number : run mode : opcode [: opcode specific data]*
- ForkedProcessEventNotifier() - Constructor for class org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessEventNotifier
- ForkedProcessEventType - Enum Class in org.apache.maven.surefire.api.booter
-
Events sent back to the plugin process.
- ForkedProcessEventType(String) - Constructor for enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
- ForkedProcessExitErrorListener - Interface in org.apache.maven.plugin.surefire.booterclient.output
- forkedProcessExitTimeoutInSeconds - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
Forked process is normally terminated without any significant delay after given tests have completed.
- forkedProcessExitTimeoutInSeconds - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
Forked process is normally terminated without any significant delay after given tests have completed.
- ForkedProcessPropertyEventListener - Interface in org.apache.maven.plugin.surefire.booterclient.output
- ForkedProcessReportEventListener<T extends ReportEntry> - Interface in org.apache.maven.plugin.surefire.booterclient.output
- ForkedProcessStackTraceEventListener - Interface in org.apache.maven.plugin.surefire.booterclient.output
- ForkedProcessStandardOutErrEventListener - Interface in org.apache.maven.plugin.surefire.booterclient.output
- ForkedProcessStringEventListener - Interface in org.apache.maven.plugin.surefire.booterclient.output
- forkedProcessTimeoutInSeconds - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
Kill the forked test process after a certain number of seconds.
- forkedProcessTimeoutInSeconds - Variable in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- forkedProcessTimeoutInSeconds - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
Kill the forked test process after a certain number of seconds.
- forkingReporterFactory - Variable in class org.apache.maven.surefire.booter.ForkedBooter
- ForkingReporterFactory - Class in org.apache.maven.surefire.api.booter
-
Creates ForkingReporters, which are typically one instance per TestSet or thread.
- ForkingReporterFactory(boolean, MasterProcessChannelEncoder) - Constructor for class org.apache.maven.surefire.api.booter.ForkingReporterFactory
- ForkingRunListener - Class in org.apache.maven.surefire.api.booter
-
Encodes the full output of the test run to the "target".
- ForkingRunListener(MasterProcessChannelEncoder, boolean) - Constructor for class org.apache.maven.surefire.api.booter.ForkingRunListener
- forkMode - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
DEPRECATED since version 2.14.
- forkNode - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
This parameter configures the forked node.
- forkNode - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
This parameter configures the forked node.
- ForkNodeArguments - Interface in org.apache.maven.surefire.api.fork
-
The properties related to the current JVM.
- forkNodeFactory - Variable in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- ForkNodeFactory - Interface in org.apache.maven.surefire.extensions
-
This is the plugin extension as a factory of
ForkChannel
. - forkNumber - Variable in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
- forkNumber - Variable in class org.apache.maven.plugin.surefire.report.ConsoleOutputFileReporter
- forkNumber - Variable in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
- ForkNumberBucket - Class in org.apache.maven.plugin.surefire.booterclient
-
A bucket from which fork numbers can be drawn.
- ForkNumberBucket() - Constructor for class org.apache.maven.plugin.surefire.booterclient.ForkNumberBucket
-
Non-public constructor
- ForkStarter - Class in org.apache.maven.plugin.surefire.booterclient
-
Starts the fork or runs in-process.
- ForkStarter(ProviderConfiguration, StartupConfiguration, ForkConfiguration, int, StartupReportConfiguration, ConsoleLogger) - Constructor for class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- ForkStarter.CloseableCloser - Class in org.apache.maven.plugin.surefire.booterclient
-
Closes stuff, with a shutdown hook to make sure things really get closed.
- ForkStarter.ForkedNodeArg - Class in org.apache.maven.plugin.surefire.booterclient
- forkTestSet - Variable in class org.apache.maven.surefire.booter.ProviderConfiguration
- FORKTESTSET - Static variable in class org.apache.maven.surefire.booter.BooterConstants
- FORKTESTSET_PREFER_TESTS_FROM_IN_STREAM - Static variable in class org.apache.maven.surefire.booter.BooterConstants
- formatElapsedTime(double) - Static method in class org.apache.maven.plugin.surefire.report.ReporterUtils
- ForwardingPrintStream(boolean, TestOutputReceiver<OutputReportEntry>) - Constructor for class org.apache.maven.surefire.api.report.ConsoleOutputCapture.ForwardingPrintStream
- free() - Method in class org.apache.maven.plugin.surefire.report.Utf8RecodingDeferredFileOutputStream
- from(Map<String, String>) - Static method in class org.apache.maven.surefire.api.util.DefaultScanResult
- fromBusyboxHours(Matcher) - Static method in class org.apache.maven.surefire.booter.PpidChecker
- fromBusyboxMinutes(Matcher) - Static method in class org.apache.maven.surefire.booter.PpidChecker
- fromBusyboxPID(Matcher) - Static method in class org.apache.maven.surefire.booter.PpidChecker
- fromClass(Class<?>) - Static method in class org.apache.maven.surefire.api.util.TestsToRun
- fromDays(Matcher) - Static method in class org.apache.maven.surefire.booter.PpidChecker
- fromFile(File) - Static method in class org.apache.maven.surefire.api.runorder.RunEntryStatisticsMap
- fromFullyQualifiedClass(String) - Static method in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- fromHours(Matcher) - Static method in class org.apache.maven.surefire.booter.PpidChecker
- fromIndex - Variable in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.Segment
- fromMinutes(Matcher) - Static method in class org.apache.maven.surefire.booter.PpidChecker
- fromPID(Matcher) - Static method in class org.apache.maven.surefire.booter.PpidChecker
- fromRunResultToFile(RunResult, File) - Static method in class org.apache.maven.plugin.failsafe.util.FailsafeSummaryXmlUtils
- fromSeconds(Matcher) - Static method in class org.apache.maven.surefire.booter.PpidChecker
- fromStream(InputStream) - Static method in class org.apache.maven.surefire.api.runorder.RunEntryStatisticsMap
- fromStrings(Collection<String>) - Static method in enum class org.apache.maven.surefire.api.cli.CommandLineOption
- FS - Static variable in class org.apache.maven.plugin.surefire.util.ScannerUtil
-
Deprecated.
- FS - Static variable in class org.apache.maven.surefire.api.filter.SpecificTestClassFilter
- FS - Static variable in class org.apache.maven.surefire.api.util.DefaultDirectoryScanner
-
Deprecated.
- fService - Variable in class org.apache.maven.surefire.junitcore.AsynchronousRunner
-
Deprecated.
- fService - Variable in class org.apache.maven.surefire.junitcore.ConfigurableParallelComputer
-
Deprecated.
- futureResults - Variable in class org.apache.maven.surefire.junitcore.pc.AbstractThreadPoolStrategy
- futures - Variable in class org.apache.maven.surefire.junitcore.AsynchronousRunner
-
Deprecated.
G
- generateFailingTestDescriptions(List<Failure>) - Static method in class org.apache.maven.surefire.common.junit4.JUnit4ProviderUtil
-
Get all descriptions from a list of Failures
- generateTestClasspath() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Generates the test classpath.
- generateThreadDump() - Static method in class org.apache.maven.surefire.booter.ForkedBooter
- GenericTestPattern<P,
C, M> - Interface in org.apache.maven.surefire.api.testset -
Resolves string test patterns in object oriented patterns
P
. - geRunmode() - Method in enum class org.apache.maven.surefire.api.report.RunMode
- get() - Static method in class org.apache.maven.surefire.api.report.ConsoleOutputReceiverForCurrentThread
- getActualClassName() - Method in class org.apache.maven.surefire.booter.StartupConfiguration
- getAdditionalClasspathElements() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getAddListenerMethod() - Method in class org.apache.maven.surefire.common.junit3.JUnit3Reflector
- getAddMethodRunHistoryMap(String) - Method in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- getAllFailures() - Method in class org.apache.maven.surefire.common.junit4.JUnitTestFailureListener
- getAlphabeticalComparator() - Method in class org.apache.maven.surefire.api.util.DefaultRunOrderCalculator
- getAnnotatedIgnore(Description) - Static method in class org.apache.maven.surefire.common.junit4.JUnit4Reflector
- getAnnotatedIgnoreValue(Description) - Static method in class org.apache.maven.surefire.common.junit4.JUnit4Reflector
- getApiArtifact() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getArgLine() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getArgLine() - Method in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- getArgLine() - Method in class org.apache.maven.plugin.surefire.booterclient.ForkConfiguration
- getArguments() - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- getArguments() - Method in class org.apache.maven.surefire.extensions.ForkChannel
- getArtifactClasspath(Artifact) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getBasedir() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getBasedir() - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
- getBasedir() - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- getBasedir() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getBasedir() - Method in interface org.apache.maven.plugin.surefire.SurefireReportParameters
- getBaseDir() - Method in class org.apache.maven.surefire.booter.ProviderConfiguration
- getBooleanProperty(String) - Method in class org.apache.maven.surefire.booter.PropertiesWrapper
- getBooterArtifact() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getBooterClasspath() - Method in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- getBooterClasspath() - Method in class org.apache.maven.plugin.surefire.booterclient.ForkConfiguration
- getByteBuffer() - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.Memento
- getByteCount() - Method in class org.apache.maven.plugin.surefire.report.Utf8RecodingDeferredFileOutputStream
- getCachableCommands() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder
-
Cached commands are sent to all alive or future alive forks.
- getCachedClassPath(String) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.ClasspathCache
- getCachedClassPath(String) - Static method in class org.apache.maven.plugin.surefire.ClasspathCache
-
Deprecated.
- getChannel() - Method in class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel
- getCharBuffer() - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.Memento
- getCharset() - Method in class org.apache.maven.surefire.api.stream.AbstractStreamEncoder
- getCharset() - Method in class org.apache.maven.surefire.booter.stream.EventEncoder
- getCharset() - Method in class org.apache.maven.surefire.stream.CommandEncoder
- getClassByName(String) - Method in class org.apache.maven.surefire.api.util.TestsToRun
-
Get test class which matches className
- getClasses() - Method in class org.apache.maven.surefire.api.util.DefaultScanResult
- getClasses() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- getClassesSkippedByValidation(ScannerFilter, ClassLoader) - Method in class org.apache.maven.surefire.api.util.DefaultScanResult
- getClassesSkippedByValidation(ScannerFilter, ClassLoader) - Method in interface org.apache.maven.surefire.api.util.ScanResult
- getClassifier() - Method in class org.apache.maven.surefire.api.testset.TestArtifactInfo
- getClassInterceptor() - Method in class org.apache.maven.surefire.junitcore.ConfigurableParallelComputer
-
Deprecated.
- getClassLoaderConfiguration() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getClassLoaderConfiguration() - Method in class org.apache.maven.surefire.booter.StartupConfiguration
- getClassMethod() - Method in class org.apache.maven.surefire.api.runorder.RunEntryStatistics
- getClassMethodIndexer() - Method in class org.apache.maven.surefire.junit.JUnit3Reporter
- getClassMethodIndexer() - Method in class org.apache.maven.surefire.junitcore.TestSet
-
Deprecated.
- getClassMethodName() - Method in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- getClassName() - Method in class org.apache.maven.surefire.api.runorder.Priority
- getClassName(int) - Method in class org.apache.maven.surefire.api.util.DefaultScanResult
- getClassName(int) - Method in interface org.apache.maven.surefire.api.util.ScanResult
- getClasspath(String) - Method in class org.apache.maven.surefire.booter.PropertiesWrapper
- getClassPath() - Method in class org.apache.maven.surefire.booter.Classpath
- getClasspathConfiguration() - Method in class org.apache.maven.surefire.booter.StartupConfiguration
- getClasspathDependencyExcludes() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getClasspathDependencyScopeExclude() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getClazz() - Method in class org.apache.maven.surefire.api.runorder.PrioritizedTest
- getClazz() - Method in class org.apache.maven.surefire.api.util.internal.ClassMethod
- getColoredTestSetSummary(WrappedReportEntry, boolean) - Method in class org.apache.maven.plugin.surefire.report.TestSetStats
- getCommandReader() - Method in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- getCommandReader() - Method in interface org.apache.maven.surefire.api.provider.ProviderParameters
- getCommandStreamBinaryFile() - Method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter.ForkedNodeArg
- getCommandStreamBinaryFile() - Method in class org.apache.maven.surefire.api.booter.DumpErrorSingleton
- getCommandStreamBinaryFile() - Method in interface org.apache.maven.surefire.api.fork.ForkNodeArguments
- getCommandStreamBinaryFile() - Method in class org.apache.maven.surefire.booter.ForkedNodeArg
- getCommandType() - Method in class org.apache.maven.surefire.api.booter.Command
- getCommonArtifact() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getCompactLogMessage(String) - Method in class org.apache.maven.surefire.booter.Classpath
- getCompletedCount() - Method in class org.apache.maven.plugin.surefire.report.TestSetStats
- getCompletedCount() - Method in class org.apache.maven.surefire.api.suite.RunResult
- getCompletedCount() - Method in class org.apache.maven.surefire.report.RunStatistics
- getConfig() - Method in class org.apache.maven.plugin.surefire.booterclient.ChecksumCalculator
- getConfigChecksum() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Operates on raw plugin parameters, not the "effective" values.
- getConfigurationParameters() - Method in class org.apache.maven.surefire.junitplatform.JUnitPlatformProvider
- getConfigurator(String) - Static method in class org.apache.maven.surefire.testng.TestNGExecutor
- getConfiguratorName(ArtifactVersion, PluginConsoleLogger) - Static method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getConnectionString() - Method in class org.apache.maven.surefire.booter.BooterDeserializer
-
Describes the current connection channel used by the client in the forked JVM in order to connect to the plugin process.
- getConsoleLock() - Method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter.ForkedNodeArg
- getConsoleLock() - Method in interface org.apache.maven.surefire.api.fork.ForkNodeArguments
- getConsoleLock() - Method in class org.apache.maven.surefire.booter.ForkedNodeArg
- getConsoleLogger() - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
- getConsoleLogger() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getConsoleLogger() - Method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter.ForkedNodeArg
- getConsoleLogger() - Method in interface org.apache.maven.surefire.api.fork.ForkNodeArguments
- getConsoleLogger() - Method in class org.apache.maven.surefire.booter.ForkedNodeArg
- getConsoleLogger() - Method in class org.apache.maven.surefire.common.junit4.JUnit4RunListener
- getConsoleLogger() - Method in class org.apache.maven.surefire.extensions.StatelessTestsetInfoConsoleReportEventListener
- getConsoleOutputReceiver() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
- getConsoleOutputReporter() - Method in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- getConstructor(Class<?>, Class<?>...) - Static method in class org.apache.maven.surefire.api.util.ReflectionUtils
- getConvertedOptions(Map<String, String>) - Method in class org.apache.maven.surefire.testng.conf.TestNG5143Configurator
- getConvertedOptions(Map<String, String>) - Method in class org.apache.maven.surefire.testng.conf.TestNG60Configurator
- getConvertedOptions(Map<String, String>) - Method in class org.apache.maven.surefire.testng.conf.TestNGMapConfigurator
- getCountdownCloseablePermits() - Method in class org.apache.maven.plugin.surefire.extensions.LegacyForkChannel
- getCountdownCloseablePermits() - Method in class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel
- getCountdownCloseablePermits() - Method in class org.apache.maven.surefire.extensions.ForkChannel
-
the permits in
CountdownCloseable
. - getData() - Method in class org.apache.maven.surefire.api.booter.Command
- getData() - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.Memento
- getDataType() - Method in enum class org.apache.maven.surefire.api.booter.MasterProcessCommand
- getDebugForkedProcess() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getDebugForkedProcess() - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- getDebugForkedProcess() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getDebugLine() - Method in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- getDebugLine() - Method in class org.apache.maven.plugin.surefire.booterclient.ForkConfiguration
- getDecodedValue() - Method in class org.apache.maven.surefire.booter.TypeEncodedValue
- getDecodedValue(ClassLoader) - Method in class org.apache.maven.surefire.booter.TypeEncodedValue
- getDecoder() - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.Memento
- getDefaultExcludes() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getDefaultIncludes() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getDefaultIncludes() - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
- getDefaultIncludes() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getDefaultIncludes() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getDefaultReporterFactory() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
- getDependenciesToScan() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getDescriptionsBeforeShutdown() - Method in class org.apache.maven.surefire.junitcore.pc.ShutdownStatus
- getDirectoryScanner() - Method in class org.apache.maven.surefire.api.booter.BaseProviderFactory
-
Deprecated.
- getDirectoryScanner() - Method in interface org.apache.maven.surefire.api.provider.ProviderParameters
-
Deprecated.Use scanresult instead, as of version 2.12.2. Will be removed in next major version.
- getDirectoryScannerParameters() - Method in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- getDirectoryScannerParameters() - Method in interface org.apache.maven.surefire.api.provider.ProviderParameters
-
Deprecated.Use scanresult instead, as of version 2.12.2. Will be removed in next major version.
- getDirScannerParams() - Method in class org.apache.maven.surefire.booter.ProviderConfiguration
- getDumpFilesToPrint() - Static method in class org.apache.maven.plugin.surefire.SurefireHelper
- getEffectiveDebugForkedProcess() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getEffectiveFailIfNoTests() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getEffectiveForkCount() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getEffectiveForkMode() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getEffectiveForkMode(String) - Static method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getEffectiveJvm() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getElapsed() - Method in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- getElapsed() - Method in interface org.apache.maven.surefire.api.report.ReportEntry
-
Gets the runtime for the item.
- getElapsed() - Method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- getElapsed() - Method in class org.apache.maven.surefire.junitcore.TestMethod
-
Deprecated.
- getElapsed(int) - Method in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- getElapsed(int) - Method in interface org.apache.maven.surefire.api.report.ReportEntry
- getElapsed(int) - Method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- getElapsedSinceLastStart() - Method in class org.apache.maven.plugin.surefire.report.TestSetStats
- getElapsedSinceTestSetStart() - Method in class org.apache.maven.plugin.surefire.report.TestSetStats
- getElapsedTimeSummary() - Method in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- getElapsedTimeVerbose() - Method in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- getEmptyTestListResolver() - Static method in class org.apache.maven.surefire.api.testset.TestListResolver
- getEnableProcessChecker() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getEnableProcessChecker() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getEnableProcessChecker() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getEncodedCharsetName() - Method in class org.apache.maven.surefire.api.stream.AbstractStreamEncoder
- getEncodedCharsetName() - Method in class org.apache.maven.surefire.booter.stream.EventEncoder
- getEncodedCharsetName() - Method in class org.apache.maven.surefire.stream.CommandEncoder
- getEncodedMagicNumber() - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- getEncodedMagicNumber() - Method in class org.apache.maven.surefire.api.stream.AbstractStreamEncoder
- getEncodedMagicNumber() - Method in class org.apache.maven.surefire.booter.stream.CommandDecoder
- getEncodedMagicNumber() - Method in class org.apache.maven.surefire.booter.stream.EventEncoder
- getEncodedMagicNumber() - Method in class org.apache.maven.surefire.stream.CommandEncoder
- getEncodedMagicNumber() - Method in class org.apache.maven.surefire.stream.EventDecoder
- getEncoding() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getEncoding() - Method in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- getEncoding() - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- getEncoding() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getEncoding() - Method in class org.apache.maven.surefire.extensions.ConsoleOutputReporter
- getEncoding() - Method in class org.apache.maven.surefire.extensions.StatelessTestsetInfoFileReportEventListener
- getEndTime() - Method in class org.apache.maven.surefire.junitcore.TestMethod
-
Deprecated.
- getEnvironmentVariables() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getEnvironmentVariables() - Method in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- getEnvironmentVariables() - Method in class org.apache.maven.plugin.surefire.booterclient.ForkConfiguration
- getErrorInFork() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
- getErrors() - Method in class org.apache.maven.plugin.surefire.report.TestSetStats
- getErrors() - Method in class org.apache.maven.surefire.api.suite.RunResult
- getErrors() - Method in class org.apache.maven.surefire.report.RunStatistics
- getEventStreamBinaryFile() - Method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter.ForkedNodeArg
- getEventStreamBinaryFile() - Method in interface org.apache.maven.surefire.api.fork.ForkNodeArguments
- getEventStreamBinaryFile() - Method in class org.apache.maven.surefire.booter.ForkedNodeArg
- getEventStreamBinaryFile(File, int) - Method in class org.apache.maven.plugin.surefire.booterclient.output.InPluginProcessDumpSingleton
- getEventType() - Method in class org.apache.maven.surefire.api.event.Event
- getException() - Method in class org.apache.maven.plugin.surefire.extensions.StreamFeeder
- getExcludedEnvironmentVariables() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getExcludedEnvironmentVariables() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getExcludedEnvironmentVariables() - Method in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- getExcludedEnvironmentVariables() - Method in class org.apache.maven.plugin.surefire.booterclient.ForkConfiguration
- getExcludedEnvironmentVariables() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getExcludedGroups() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getExcludedPatterns() - Method in interface org.apache.maven.surefire.api.testset.GenericTestPattern
- getExcludedPatterns() - Method in class org.apache.maven.surefire.api.testset.TestListResolver
- getExcludedScanList() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getExcludeJUnit5Engines() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getExcludeJUnit5Engines() - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- getExcludeJUnit5Engines() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getExcludeList() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getExcludeList(boolean) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Computes a merge list of test exclusions.
- getExcludes() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getExcludes() - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- getExcludes() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getExcludes() - Method in class org.apache.maven.surefire.api.testset.DirectoryScannerParameters
-
Deprecated.
- getExcludes() - Method in class org.apache.maven.surefire.booter.ProviderConfiguration
-
Deprecated.
- getExcludesFile() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getExcludesFile() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getExcludesFile() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getExtensionsArtifact() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getFailIfNoSpecifiedTests() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getFailIfNoSpecifiedTests() - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- getFailIfNoSpecifiedTests() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getFailIfNoTests() - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
- getFailIfNoTests() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getFailIfNoTests() - Method in interface org.apache.maven.plugin.surefire.SurefireReportParameters
- getFailOnFlakeCount() - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
- getFailOnFlakeCount() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getFailOnFlakeCount() - Method in interface org.apache.maven.plugin.surefire.SurefireReportParameters
- getFailsafeCode() - Method in class org.apache.maven.surefire.api.suite.RunResult
- getFailure() - Method in class org.apache.maven.surefire.api.suite.RunResult
- getFailures() - Method in class org.apache.maven.plugin.surefire.report.TestSetStats
- getFailures() - Method in class org.apache.maven.surefire.api.suite.RunResult
- getFailures() - Method in class org.apache.maven.surefire.junitplatform.RunListenerAdapter
- getFailures() - Method in class org.apache.maven.surefire.report.RunStatistics
- getFileProperty(String) - Method in class org.apache.maven.surefire.booter.PropertiesWrapper
- getFilters() - Method in class org.apache.maven.surefire.junitplatform.JUnitPlatformProvider
- getFlakes() - Method in class org.apache.maven.surefire.api.suite.RunResult
- getFlakes() - Method in class org.apache.maven.surefire.report.RunStatistics
- getFlakyXmlTag() - Method in enum class org.apache.maven.plugin.surefire.report.ReportEntryType
- getForkChannelId() - Method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter.ForkedNodeArg
- getForkChannelId() - Method in interface org.apache.maven.surefire.api.fork.ForkNodeArguments
-
The index of the forked JVM, from 1 to N.
- getForkChannelId() - Method in class org.apache.maven.surefire.booter.ForkedNodeArg
- getForkCount() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getForkCount() - Method in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- getForkCount() - Method in class org.apache.maven.plugin.surefire.booterclient.ForkConfiguration
- getForkedProcessExitTimeoutInSeconds() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getForkedProcessExitTimeoutInSeconds() - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- getForkedProcessExitTimeoutInSeconds() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getForkedProcessTimeoutInSeconds() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getForkedProcessTimeoutInSeconds() - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- getForkedProcessTimeoutInSeconds() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getForkMode() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getForkNode() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getForkNode() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getForkNode() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getForkNodeConnectionString() - Method in class org.apache.maven.plugin.surefire.extensions.LegacyForkChannel
- getForkNodeConnectionString() - Method in class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel
- getForkNodeConnectionString() - Method in class org.apache.maven.surefire.extensions.ForkChannel
-
This is server related class, which if binds to a TCP port, determines the connection string for the client.
- getForkNodeFactory() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getForkNodeFactory() - Method in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- getForkNodeFactory() - Method in class org.apache.maven.plugin.surefire.booterclient.ForkConfiguration
- getForkNumber() - Method in class org.apache.maven.surefire.booter.BooterDeserializer
- getFutureResults() - Method in class org.apache.maven.surefire.junitcore.pc.AbstractThreadPoolStrategy
- getGlobalRunStatistics() - Method in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
- getGroup() - Method in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- getGroup() - Method in class org.apache.maven.surefire.api.report.CategorizedReportEntry
- getGroup() - Method in interface org.apache.maven.surefire.api.report.ReportEntry
-
The group/category of the testcase
- getGroup() - Method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- getGroups() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getHighestDrawnNumber() - Method in class org.apache.maven.plugin.surefire.booterclient.ForkNumberBucket
- getImmediateCommands() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder
-
Only
NotifiableTestStream.noop()
andNotifiableTestStream.shutdown(Shutdown)
are supported. - getIncludedAndExcludedTests() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getIncludedPatterns() - Method in interface org.apache.maven.surefire.api.testset.GenericTestPattern
- getIncludedPatterns() - Method in class org.apache.maven.surefire.api.testset.TestListResolver
- getIncludedScanList() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getIncludeJUnit5Engines() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getIncludeJUnit5Engines() - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- getIncludeJUnit5Engines() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getIncludeList() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getIncludeList(boolean) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Computes a merge list of test inclusions.
- getIncludes() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getIncludes() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getIncludes() - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- getIncludes() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getIncludes() - Method in class org.apache.maven.surefire.api.testset.DirectoryScannerParameters
-
Deprecated.
- getIncludes() - Method in class org.apache.maven.surefire.booter.ProviderConfiguration
-
Deprecated.
- getIncludesFile() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getIncludesFile() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getIncludesFile() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getIncompleteTests() - Method in class org.apache.maven.surefire.junitcore.pc.ShutdownResult
- getInprocClasspath() - Method in class org.apache.maven.surefire.booter.AbstractPathConfiguration
- getInprocClasspath() - Method in class org.apache.maven.surefire.booter.ClasspathConfiguration
- getInprocClasspath() - Method in class org.apache.maven.surefire.booter.ModularClasspathConfiguration
- getInprocTestClasspath() - Method in class org.apache.maven.surefire.booter.AbstractPathConfiguration
- getInstance() - Static method in class org.apache.maven.plugin.surefire.booterclient.ForkNumberBucket
- getInstance() - Static method in class org.apache.maven.surefire.testng.utils.FailFastEventsSingleton
- getInterfacesImplementedByDynamicProxy() - Method in class org.apache.maven.surefire.common.junit3.JUnit3Reflector
- getIntProperty(String) - Method in class org.apache.maven.surefire.booter.PropertiesWrapper
- getIterableCachable() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder
-
The iterator is not thread safe.
- getIterableClasses(MasterProcessChannelEncoder) - Method in class org.apache.maven.surefire.booter.CommandReader
-
The iterator can be used only in one Thread.
- getJdkExecAttributesForTests() - Method in class org.apache.maven.plugin.surefire.booterclient.Platform
- getJdkForTests() - Method in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- getJdkForTests() - Method in class org.apache.maven.plugin.surefire.booterclient.ForkConfiguration
- getJdkHome() - Method in class org.apache.maven.plugin.surefire.JdkAttributes
- getJdkToolchain() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getJpmsArgs() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnitPlatformProviderInfo
- getJpmsArguments() - Method in class org.apache.maven.surefire.booter.StartupConfiguration
- getJpmsArguments(ProviderRequirements) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.DynamicProviderInfo
- getJpmsArguments(ProviderRequirements) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnit3ProviderInfo
- getJpmsArguments(ProviderRequirements) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnit4ProviderInfo
- getJpmsArguments(ProviderRequirements) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnitCoreProviderInfo
- getJpmsArguments(ProviderRequirements) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnitPlatformProviderInfo
- getJpmsArguments(ProviderRequirements) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.TestNgProviderInfo
- getJpmsArguments(ProviderRequirements) - Method in interface org.apache.maven.surefire.providerapi.ProviderInfo
- getJUnit5Artifact() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getJunitArtifact() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getJunitArtifactName() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getJunitDepArtifact() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getJUnitPlatformRunnerArtifact() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getJvm() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getJvmExecutable() - Method in class org.apache.maven.plugin.surefire.JdkAttributes
- getJvmTerminator() - Method in class org.apache.maven.surefire.booter.ForkedBooter
- getKey() - Method in class org.apache.maven.surefire.api.event.SystemPropertyEvent
- getKey() - Method in class org.apache.maven.surefire.api.util.internal.ImmutableMap.Node
- getLargeCache(int) - Method in class org.apache.maven.plugin.surefire.report.Utf8RecodingDeferredFileOutputStream
- getLine() - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.Memento
- getLocalIndex() - Method in class org.apache.maven.surefire.report.ClassMethodIndexer
- getLocalizedMessage() - Method in exception org.apache.maven.plugin.surefire.booterclient.output.MultipleFailureException
- getLocalizedMessage() - Method in class org.apache.maven.surefire.api.report.SafeThrowable
- getLocalRepository() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getLocalRepository() - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- getLocatedClasses() - Method in class org.apache.maven.surefire.api.util.TestsToRun
- getLocationManager() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
For testing purposes - Mockito.
- getLog() - Method in interface org.apache.maven.surefire.api.report.OutputReportEntry
- getLog() - Method in class org.apache.maven.surefire.api.report.TestOutputReportEntry
- getLogger() - Method in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- getLoggerApiArtifact() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getLogicalStream() - Method in class org.apache.maven.surefire.junitcore.TestMethod
-
Deprecated.
- getLogMessage(String) - Method in class org.apache.maven.surefire.booter.Classpath
- getLogPrefix() - Method in enum class org.apache.maven.plugin.surefire.report.DefaultReporterFactory.TestResultType
- getLongProperty(String) - Method in class org.apache.maven.surefire.booter.PropertiesWrapper
- getMainBuildPath() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getMainBuildPath() - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- getMainBuildPath() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getMainCliOptions() - Method in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- getMainCliOptions() - Method in interface org.apache.maven.surefire.api.provider.ProviderParameters
- getMainCliOptions() - Method in class org.apache.maven.surefire.booter.ProviderConfiguration
- getManuallyConfiguredProviders() - Method in class org.apache.maven.surefire.providerapi.ProviderDetector
- getMessage() - Method in exception org.apache.maven.plugin.surefire.booterclient.output.MultipleFailureException
- getMessage() - Method in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- getMessage() - Method in class org.apache.maven.surefire.api.event.AbstractConsoleEvent
- getMessage() - Method in class org.apache.maven.surefire.api.event.AbstractStandardStreamEvent
- getMessage() - Method in interface org.apache.maven.surefire.api.report.ReportEntry
-
A message relating to a non-successful termination.
- getMessage() - Method in class org.apache.maven.surefire.api.report.SafeThrowable
- getMessage() - Method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- getMethod() - Method in class org.apache.maven.surefire.api.util.internal.ClassMethod
- getMethod(Class<?>, String, Class<?>...) - Static method in class org.apache.maven.surefire.api.util.ReflectionUtils
- getMethod(Class<?>, String, Class<?>...) - Static method in class org.apache.maven.surefire.common.junit3.JUnit3Reflector
- getMethod(Object, String, Class<?>...) - Static method in class org.apache.maven.surefire.api.util.ReflectionUtils
- getMethodInterceptor() - Method in class org.apache.maven.surefire.junitcore.ConfigurableParallelComputer
-
Deprecated.
- getMinSuccessRate() - Method in class org.apache.maven.surefire.api.runorder.Priority
- getModelProperties() - Method in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- getModelProperties() - Method in class org.apache.maven.plugin.surefire.booterclient.ForkConfiguration
- getModularClasspath() - Method in class org.apache.maven.surefire.booter.ModularClasspathConfiguration
- getModuleNameFromDescriptor() - Method in class org.apache.maven.surefire.booter.ModularClasspath
- getModulePath() - Method in class org.apache.maven.surefire.booter.ModularClasspath
- getMojoArtifact() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
This plugin MOJO artifact.
- getName() - Method in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- getName() - Method in interface org.apache.maven.surefire.api.report.ReportEntry
-
The name of the test case
- getName() - Method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- getNameText() - Method in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- getNameText() - Method in interface org.apache.maven.surefire.api.report.ReportEntry
-
Human readable
test case
. - getNameText() - Method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- getNameWithGroup() - Method in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- getNameWithGroup() - Method in class org.apache.maven.surefire.api.report.CategorizedReportEntry
- getNameWithGroup() - Method in interface org.apache.maven.surefire.api.report.ReportEntry
-
A source name of the test case together with the group or category (if any exists).
- getNameWithGroup() - Method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- getNestedClasses() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- getNestedSuites() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- getNotParallelRunners() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- getObjectFactory() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getOpcode() - Method in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
- getOpcodeBinary() - Method in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
- getOpcodeBinary() - Method in enum class org.apache.maven.surefire.api.booter.MasterProcessCommand
- getOpcodeLength() - Method in enum class org.apache.maven.surefire.api.booter.MasterProcessCommand
- getOptions() - Method in class org.apache.maven.surefire.testng.TestNGDirectoryTestSuite
- getOptions() - Method in class org.apache.maven.surefire.testng.TestNGXmlTestSuite
- getOptions() - Method in class org.apache.maven.surefire.testng.TestSuite
- getOrCreateConsoleLogger() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
- getOrCreateThreadAttachedTestMethod(ReportEntry) - Method in class org.apache.maven.surefire.junitcore.ConcurrentRunListener
-
Deprecated.
- getOSSpecificIllegalChars() - Static method in class org.apache.maven.plugin.surefire.report.FileReporterUtils
- getOutput(boolean) - Method in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- getOutputStream(WrappedReportEntry) - Method in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- getP1() - Method in class org.apache.maven.surefire.api.booter.BiProperty
- getP2() - Method in class org.apache.maven.surefire.api.booter.BiProperty
- getPackages() - Method in class org.apache.maven.surefire.booter.ModularClasspath
- getParallel() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getParallelTestsTimeoutForcedInSeconds() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getParallelTestsTimeoutForcedInSeconds() - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- getParallelTestsTimeoutForcedInSeconds() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getParallelTestsTimeoutForcedInSeconds() - Method in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- getParallelTestsTimeoutInSeconds() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getParallelTestsTimeoutInSeconds() - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- getParallelTestsTimeoutInSeconds() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getParallelTestsTimeoutInSeconds() - Method in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- getParam() - Method in enum class org.apache.maven.surefire.api.booter.Shutdown
- getPatchFile() - Method in class org.apache.maven.surefire.booter.ModularClasspath
- getPerCoreThreadCount() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getPID() - Method in class org.apache.maven.surefire.booter.ProcessInfo
- getPluginArtifactMap() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getPluginDescriptor() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getPluginName() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getPluginName() - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
- getPluginName() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getPluginName() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getPluginParameterTest() - Method in interface org.apache.maven.surefire.api.testset.GenericTestPattern
- getPluginParameterTest() - Method in class org.apache.maven.surefire.api.testset.TestListResolver
- getPluginPid() - Method in class org.apache.maven.plugin.surefire.booterclient.Platform
- getPluginPid() - Method in class org.apache.maven.surefire.booter.BooterDeserializer
- getPluginPlatform() - Method in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- getPluginPlatform() - Method in class org.apache.maven.plugin.surefire.booterclient.ForkConfiguration
- getPoolCapacity() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- getPositionByteBuffer() - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.BufferedStream
- getPriorities(Comparator<Priority>) - Method in class org.apache.maven.surefire.api.runorder.RunEntryStatisticsMap
- getPrioritizedTests(List<Class<?>>, Comparator<Priority>) - Method in class org.apache.maven.surefire.api.runorder.RunEntryStatisticsMap
- getPrioritizedTestsByFailureFirst(List<Class<?>>) - Method in class org.apache.maven.surefire.api.runorder.RunEntryStatisticsMap
- getPrioritizedTestsClassRunTime(List<Class<?>>, int) - Method in class org.apache.maven.surefire.api.runorder.RunEntryStatisticsMap
- getPriority() - Method in class org.apache.maven.surefire.api.runorder.PrioritizedTest
- getPriority() - Method in class org.apache.maven.surefire.api.runorder.Priority
- getProcessChecker() - Method in class org.apache.maven.surefire.booter.StartupConfiguration
- getProcessName() - Static method in class org.apache.maven.surefire.booter.ForkedBooter
- getProject() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getProjectArtifactMap() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getProjectBuildDirectory() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getProjectRemoteRepositories() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getProjectTestArtifacts() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getProperties() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getProperties() - Method in class org.apache.maven.surefire.booter.PropertiesWrapper
- getPropertiesList(String) - Method in class org.apache.maven.surefire.junitplatform.JUnitPlatformProvider
- getProperty(String) - Method in class org.apache.maven.surefire.booter.PropertiesWrapper
- getProviderClassName() - Method in class org.apache.maven.surefire.booter.StartupConfiguration
- getProviderClasspath() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.DynamicProviderInfo
- getProviderClasspath() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnit3ProviderInfo
- getProviderClasspath() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnit4ProviderInfo
- getProviderClasspath() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnitCoreProviderInfo
- getProviderClasspath() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnitPlatformProviderInfo
- getProviderClasspath() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.TestNgProviderInfo
- getProviderClasspath() - Method in class org.apache.maven.surefire.booter.AbstractPathConfiguration
- getProviderClasspath() - Method in interface org.apache.maven.surefire.providerapi.ProviderInfo
- getProviderClasspath(String, String) - Method in class org.apache.maven.plugin.surefire.SurefireDependencyResolver
- getProviderClasspathAsMap(String, String) - Method in class org.apache.maven.plugin.surefire.SurefireDependencyResolver
- getProviderName() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.DynamicProviderInfo
- getProviderName() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnit3ProviderInfo
- getProviderName() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnit4ProviderInfo
- getProviderName() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnitCoreProviderInfo
- getProviderName() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnitPlatformProviderInfo
- getProviderName() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.TestNgProviderInfo
- getProviderName() - Method in interface org.apache.maven.surefire.providerapi.ProviderInfo
- getProviderProperties() - Method in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- getProviderProperties() - Method in interface org.apache.maven.surefire.api.provider.ProviderParameters
-
The per-provider specific properties that may come all the way from the plugin's properties setting.
- getProviderProperties() - Method in class org.apache.maven.surefire.booter.ProviderConfiguration
- getReader(URL) - Static method in class org.apache.maven.surefire.providerapi.ServiceLoader
- getRemainingTestClasses() - Method in class org.apache.maven.surefire.common.junit4.Notifier
- getRemoteRepositories() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getReportEntries() - Method in class org.apache.maven.plugin.surefire.report.TestSetStats
- getReportEntry() - Method in class org.apache.maven.surefire.api.event.AbstractTestControlEvent
- getReportEntryType() - Method in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- getReporter() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
-
Used when getting reporters on the plugin side of a fork.
- getReporterConfiguration() - Method in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- getReporterConfiguration() - Method in interface org.apache.maven.surefire.api.provider.ProviderParameters
-
The raw parameters used in creating the ReporterManagerFactory
- getReporterConfiguration() - Method in class org.apache.maven.surefire.booter.ProviderConfiguration
- getReporterFactory() - Method in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- getReporterFactory() - Method in interface org.apache.maven.surefire.api.provider.ProviderParameters
-
Provides features for creating reporting objects
- getReportFile(File, String, String, String) - Static method in class org.apache.maven.plugin.surefire.report.FileReporter
- getReportFile(WrappedReportEntry) - Method in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- getReportFormat() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getReportFormat() - Method in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- getReportFormat() - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- getReportFormat() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getReportName() - Method in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- getReportNameSuffix() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getReportNameSuffix() - Method in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- getReportNameSuffix() - Method in class org.apache.maven.surefire.extensions.StatelessReportMojoConfiguration
- getReportNameSuffix() - Method in class org.apache.maven.surefire.extensions.StatelessTestsetInfoFileReportEventListener
- getReportNameWithGroup() - Method in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- getReportNameWithGroup() - Method in class org.apache.maven.surefire.api.report.CategorizedReportEntry
- getReportNameWithGroup() - Method in interface org.apache.maven.surefire.api.report.ReportEntry
-
A source text of the test case together with the group or category (if any exists).
- getReportNameWithGroup() - Method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- getReportSchemaLocation() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getReportSchemaLocation() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getReportSchemaLocation() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getReportsDirectory() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getReportsDirectory() - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
- getReportsDirectory() - Method in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
- getReportsDirectory() - Method in interface org.apache.maven.plugin.surefire.report.ReportsMerger
- getReportsDirectory() - Method in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- getReportsDirectory() - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- getReportsDirectory() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getReportsDirectory() - Method in interface org.apache.maven.plugin.surefire.SurefireReportParameters
- getReportsDirectory() - Method in class org.apache.maven.surefire.api.report.ReporterConfiguration
-
The directory where reports will be created, normally ${project.build.directory}/surefire-reports
- getReportsDirectory() - Method in class org.apache.maven.surefire.extensions.StatelessReportMojoConfiguration
- getReportsDirectory() - Method in class org.apache.maven.surefire.extensions.StatelessTestsetInfoFileReportEventListener
- getReportSourceName() - Method in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- getReportSourceName(String) - Method in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- getRepositorySystem() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getRerunFailingTestsCount() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getRerunFailingTestsCount() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getRerunFailingTestsCount() - Method in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- getRerunFailingTestsCount() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getRerunFailingTestsCount() - Method in class org.apache.maven.surefire.api.testset.TestRequest
-
How many times to rerun failing tests, issued with -Dsurefire.rerunFailingTestsCount from the command line.
- getRerunFailingTestsCount() - Method in class org.apache.maven.surefire.extensions.StatelessReportMojoConfiguration
- getRerunXmlTag() - Method in enum class org.apache.maven.plugin.surefire.report.ReportEntryType
- getResolvePathResult() - Method in class org.apache.maven.plugin.surefire.ResolvePathResultWrapper
- getResult() - Method in class org.apache.maven.surefire.api.runorder.ThreadedExecutionScheduler
- getResultType() - Method in class org.apache.maven.plugin.surefire.report.TestMethodStats
- getReverseAlphabeticalComparator() - Method in class org.apache.maven.surefire.api.util.DefaultRunOrderCalculator
- getRunListener() - Method in class org.apache.maven.surefire.junitcore.ConcurrentRunListener
-
Deprecated.
- getRunListener() - Method in class org.apache.maven.surefire.testng.TestNGReporter
- getRunMethod(Class<?>) - Method in class org.apache.maven.surefire.common.junit3.JUnit3Reflector
- getRunMode() - Method in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- getRunMode() - Method in class org.apache.maven.surefire.api.event.AbstractStandardStreamEvent
- getRunMode() - Method in class org.apache.maven.surefire.api.event.SystemPropertyEvent
- getRunMode() - Method in interface org.apache.maven.surefire.api.report.ReportEntry
-
Run mode.
- getRunMode() - Method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- getRunMode() - Method in class org.apache.maven.surefire.api.report.TestOutputReportEntry
- getRunMode() - Method in class org.apache.maven.surefire.common.junit4.JUnit4RunListener
- getRunMode() - Method in class org.apache.maven.surefire.junitcore.TestSet
-
Deprecated.
- getRunmodeBinary() - Method in enum class org.apache.maven.surefire.api.report.RunMode
- getRunner() - Method in class org.apache.maven.surefire.junitcore.FilteringRequest
- getRunner(RunnerBuilder, Class<?>) - Method in class org.apache.maven.surefire.junitcore.ConfigurableParallelComputer
-
Deprecated.
- getRunner(RunnerBuilder, Class<?>) - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- getRunOrder() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getRunOrder() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getRunOrder() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getRunOrder() - Method in class org.apache.maven.surefire.api.testset.DirectoryScannerParameters
- getRunOrder() - Method in class org.apache.maven.surefire.api.testset.RunOrderParameters
- getRunOrderCalculator() - Method in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- getRunOrderCalculator() - Method in interface org.apache.maven.surefire.api.provider.ProviderParameters
-
Provides a service to calculate run order of tests.
- getRunOrderParameters() - Method in class org.apache.maven.surefire.booter.ProviderConfiguration
- getRunOrderRandomSeed() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getRunOrderRandomSeed() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getRunOrderRandomSeed() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getRunOrderRandomSeed() - Method in class org.apache.maven.surefire.api.testset.RunOrderParameters
- getRunOrders() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getRunResult() - Method in class org.apache.maven.surefire.report.RunStatistics
- getRunStatisticsFile() - Method in class org.apache.maven.surefire.api.testset.RunOrderParameters
- getRunTime() - Method in class org.apache.maven.surefire.api.runorder.RunEntryStatistics
- getScanResult() - Method in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- getScanResult() - Method in interface org.apache.maven.surefire.api.provider.ProviderParameters
-
Provides the result of the directory scan performed in the plugin
- getSession() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getSessionId() - Method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter.ForkedNodeArg
- getSessionId() - Method in interface org.apache.maven.surefire.api.fork.ForkNodeArguments
- getSessionId() - Method in class org.apache.maven.surefire.booter.ForkedNodeArg
- getSha1() - Method in class org.apache.maven.plugin.surefire.booterclient.ChecksumCalculator
- getShadefireArtifact() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getShutdown() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getShutdown() - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- getShutdown() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getShutdown() - Method in class org.apache.maven.surefire.booter.ProviderConfiguration
- getShutdownScheduler() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputer
- getSingleton() - Static method in class org.apache.maven.plugin.surefire.booterclient.output.InPluginProcessDumpSingleton
- getSingleton() - Static method in class org.apache.maven.surefire.api.booter.DumpErrorSingleton
- getSkipAfterFailureCount() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getSkipAfterFailureCount() - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- getSkipAfterFailureCount() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getSkipAfterFailureCount() - Method in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- getSkipAfterFailureCount() - Method in interface org.apache.maven.surefire.api.provider.ProviderParameters
- getSkipAfterFailureCount() - Method in class org.apache.maven.surefire.booter.ProviderConfiguration
- getSkipAfterFailureCount() - Method in class org.apache.maven.surefire.junit4.JUnit4Provider
- getSkipAfterFailureCount() - Method in class org.apache.maven.surefire.junitcore.JUnitCoreProvider
- getSkipAfterFailureCount() - Method in class org.apache.maven.surefire.testng.TestNGProvider
- getSkipped() - Method in class org.apache.maven.plugin.surefire.report.TestSetStats
- getSkipped() - Method in class org.apache.maven.surefire.api.suite.RunResult
- getSkipped() - Method in class org.apache.maven.surefire.report.RunStatistics
- getSortOrderComparator(RunOrder) - Method in class org.apache.maven.surefire.api.util.DefaultRunOrderCalculator
- getSourceName() - Method in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- getSourceName() - Method in interface org.apache.maven.surefire.api.report.ReportEntry
-
The class name of the test
- getSourceName() - Method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- getSourceName(String) - Method in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- getSourceText() - Method in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- getSourceText() - Method in interface org.apache.maven.surefire.api.report.ReportEntry
-
Human readable
test class
. - getSourceText() - Method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- getSpecificTests() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getSpecificTests() - Method in class org.apache.maven.surefire.api.testset.DirectoryScannerParameters
-
Deprecated.
- getSpiArtifact() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getStackTrace(boolean) - Method in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- getStackTrace(Exception) - Static method in class org.apache.maven.surefire.api.suite.RunResult
- getStackTraceWriter() - Method in class org.apache.maven.plugin.surefire.report.TestMethodStats
- getStackTraceWriter() - Method in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- getStackTraceWriter() - Method in class org.apache.maven.surefire.api.event.ConsoleErrorEvent
- getStackTraceWriter() - Method in class org.apache.maven.surefire.api.event.JvmExitErrorEvent
- getStackTraceWriter() - Method in interface org.apache.maven.surefire.api.report.ReportEntry
-
The group/category of the testcase
- getStackTraceWriter() - Method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- getStartTime() - Method in class org.apache.maven.surefire.junitcore.TestMethod
-
Deprecated.
- getStartupConfiguration() - Method in class org.apache.maven.surefire.booter.BooterDeserializer
- getStartupReportConfiguration(String, boolean) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getStatisticsFile() - Method in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- getStatisticsFile(String) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getStatisticsReporter() - Method in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- getStdErr() - Method in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- getStdErrChannel() - Method in class org.apache.maven.surefire.extensions.util.CommandlineStreams
- getStdInChannel() - Method in class org.apache.maven.surefire.extensions.util.CommandlineStreams
- getStdout() - Method in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- getStdOutChannel() - Method in class org.apache.maven.surefire.extensions.util.CommandlineStreams
- getString() - Method in class org.apache.maven.surefire.report.SmartStackTraceParser
- getStringKeySet() - Method in class org.apache.maven.plugin.surefire.SurefireProperties
- getStringList(String) - Method in class org.apache.maven.surefire.booter.PropertiesWrapper
- getSuccessfulBuilds() - Method in class org.apache.maven.surefire.api.runorder.RunEntryStatistics
- getSuite(RunnerBuilder, Class<?>[]) - Method in class org.apache.maven.surefire.junitcore.ConfigurableParallelComputer
-
Deprecated.
- getSuite(RunnerBuilder, Class<?>[]) - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- getSuiteName() - Method in class org.apache.maven.surefire.testng.TestSuite
- getSuites() - Method in interface org.apache.maven.surefire.api.provider.SurefireProvider
-
Determines the number of forks.
- getSuites() - Method in class org.apache.maven.surefire.booter.ProviderFactory.ProviderProxy
- getSuites() - Method in class org.apache.maven.surefire.junit.JUnit3Provider
- getSuites() - Method in class org.apache.maven.surefire.junit4.JUnit4Provider
- getSuites() - Method in class org.apache.maven.surefire.junitcore.JUnitCoreProvider
- getSuites() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- getSuites() - Method in class org.apache.maven.surefire.junitplatform.JUnitPlatformProvider
- getSuites() - Method in class org.apache.maven.surefire.testng.TestNGProvider
- getSuitesIterator() - Method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- getSuiteXmlFiles() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getSuiteXmlFiles() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getSuiteXmlFiles() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getSuiteXmlFiles() - Method in class org.apache.maven.surefire.api.testset.TestRequest
-
Represents suitexmlfiles that define the test-run request
- getSummary() - Method in class org.apache.maven.surefire.report.RunStatistics
- getSummaryFile() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getSurefireSharedUtilsArtifact() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getSurefireTempDir() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Where surefire stores its own temp files
- getSystemExitTimeout() - Method in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- getSystemExitTimeout() - Method in interface org.apache.maven.surefire.api.provider.ProviderParameters
- getSystemExitTimeout() - Method in class org.apache.maven.surefire.booter.ProviderConfiguration
- getSystemProperties() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getSystemProperties() - Method in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- getSystemProperties() - Method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- getSystemProperties() - Method in interface org.apache.maven.surefire.api.report.TestSetReportEntry
- getSystemPropertiesFile() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getSystemPropertiesFile() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
List of System properties, loaded from a file, to pass to the JUnit tests.
- getSystemPropertiesFile() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getSystemPropertyVariables() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getTarget() - Method in class org.apache.maven.surefire.api.report.SafeThrowable
- getTempDir() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getTempDirectory() - Method in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- getTempDirectory() - Method in class org.apache.maven.plugin.surefire.booterclient.ForkConfiguration
- getTest() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getTest() - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- getTest() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getTestArtifact() - Method in class org.apache.maven.surefire.booter.ProviderConfiguration
- getTestArtifactInfo() - Method in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- getTestArtifactInfo() - Method in interface org.apache.maven.surefire.api.provider.ProviderParameters
-
Artifact info about the artifact used to autodetect provider
- getTestClassesDirectory() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- getTestClassesDirectory() - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
- getTestClassesDirectory() - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- getTestClassesDirectory() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- getTestClassesDirectory() - Method in interface org.apache.maven.plugin.surefire.SurefireReportParameters
- getTestClassesDirectory() - Method in class org.apache.maven.surefire.api.testset.DirectoryScannerParameters
-
Returns the directory of the compiled classes, normally ${project.build.testOutputDirectory}
- getTestClassLoader() - Method in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- getTestClassLoader() - Method in interface org.apache.maven.surefire.api.provider.ProviderParameters
-
The class loader for the tests
- getTestClassMethodName() - Method in class org.apache.maven.plugin.surefire.report.TestMethodStats
- getTestClassMethodRunHistory() - Method in class org.apache.maven.plugin.surefire.extensions.DefaultStatelessReportMojoConfiguration
-
Deprecated.
- getTestClasspath() - Method in class org.apache.maven.surefire.booter.AbstractPathConfiguration
- getTestClasspath() - Method in class org.apache.maven.surefire.booter.ClasspathConfiguration
- getTestClasspath() - Method in class org.apache.maven.surefire.booter.ModularClasspathConfiguration
- getTestClassPattern() - Method in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.Test class file pattern, e.g.
- getTestConstructor(Class<?>) - Static method in class org.apache.maven.surefire.common.junit3.JUnit3Reflector
- getTestDependencies() - Method in class org.apache.maven.plugin.surefire.TestClassPath
- getTestFilter() - Method in class org.apache.maven.surefire.testng.TestNGProvider
- getTestForFork() - Method in class org.apache.maven.surefire.booter.ProviderConfiguration
- getTestInterface() - Method in class org.apache.maven.surefire.common.junit3.JUnit3Reflector
- getTestInterfaceRunMethod() - Method in class org.apache.maven.surefire.common.junit3.JUnit3Reflector
- getTestListResolver() - Method in class org.apache.maven.surefire.api.testset.TestRequest
-
A specific test request issued with -Dtest= from the command line.
- getTestMethodPattern() - Method in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.Test method, e.g.
- getTestMethodStats() - Method in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- getTestName(String, String) - Method in class org.apache.maven.surefire.junit.PojoTestSetExecutor
- getTestNgArtifact() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getTestNGArtifactName() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getTestProblems(OutputStreamWriter, XMLWriter, WrappedReportEntry, boolean, OutputStream, String, boolean) - Static method in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- getTestRequest() - Method in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- getTestRequest() - Method in interface org.apache.maven.surefire.api.provider.ProviderParameters
-
Contains information about requested test suites or individual tests from the command line.
- getTestResultClass() - Method in class org.apache.maven.surefire.common.junit3.JUnit3Reflector
- getTestResults() - Method in class org.apache.maven.plugin.surefire.report.TestSetStats
- getTestResultType(List<ReportEntryType>, int) - Static method in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
-
Get the result of a test based on all its runs.
- getTestResultType(List<WrappedReportEntry>) - Method in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
-
Get the result of a test from a list of its runs in WrappedReportEntry
- getTestRunId() - Method in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- getTestRunId() - Method in class org.apache.maven.surefire.api.event.AbstractStandardStreamEvent
- getTestRunId() - Method in class org.apache.maven.surefire.api.event.SystemPropertyEvent
- getTestRunId() - Method in interface org.apache.maven.surefire.api.report.ReportEntry
-
This represents a reference pointing to a literal representation of test description or literal unique id.
- getTestRunId() - Method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- getTestRunId() - Method in class org.apache.maven.surefire.api.report.TestOutputReportEntry
- getTestSet() - Method in class org.apache.maven.surefire.junitcore.TestMethod
-
Deprecated.
- getTestSet(ReportEntry) - Method in class org.apache.maven.surefire.junitcore.ConcurrentRunListener
-
Deprecated.
- getTestsetReporter() - Method in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- getTestSetReporter() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
-
Only
ForkClient.getConsoleOutputReceiver()
may call this method in another Thread. - getTestSetSummary(WrappedReportEntry, boolean) - Method in class org.apache.maven.plugin.surefire.report.TestSetStats
- getTestSourceDirectory() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getTestSourceDirectory() - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- getTestSourceDirectory() - Method in class org.apache.maven.surefire.api.testset.TestRequest
-
Test source directory, normally ${project.build.testSourceDirectory}
- getTestSuiteDefinition() - Method in class org.apache.maven.surefire.booter.ProviderConfiguration
- getTestVmSystemProperties() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
- getThreadCount() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getThreadCount() - Method in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- getThreadCount() - Method in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- getThreadCountClasses() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getThreadCountClasses() - Method in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- getThreadCountMethods() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getThreadCountMethods() - Method in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- getThreadCountSuites() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getThreadCountSuites() - Method in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- getThreadPool() - Method in class org.apache.maven.surefire.junitcore.pc.AbstractThreadPoolStrategy
- getThreadTestMethod() - Static method in class org.apache.maven.surefire.junitcore.TestMethod
-
Deprecated.
- getThreadTestSet() - Static method in class org.apache.maven.surefire.junitcore.TestSet
-
Deprecated.
- getThrowable() - Method in class org.apache.maven.plugin.surefire.booterclient.output.DeserializedStacktraceWriter
- getThrowable() - Method in class org.apache.maven.surefire.api.report.LegacyPojoStackTraceWriter
- getThrowable() - Method in interface org.apache.maven.surefire.api.report.StackTraceWriter
-
Retrieve the throwable for this writer.
- getThrowable() - Method in class org.apache.maven.surefire.common.junit4.JUnit4StackTraceWriter
-
Returns the exception associated with this failure.
- getThrowable() - Method in class org.apache.maven.surefire.report.PojoStackTraceWriter
- getTime() - Method in class org.apache.maven.surefire.booter.ProcessInfo
- getToolchain() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getToolchainManager() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getToolchainMaven33x(Class<T>, T, MavenSession, Map<String, String>) - Static method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getTotalRuntime() - Method in class org.apache.maven.surefire.api.runorder.PrioritizedTest
- getTotalRuntime() - Method in class org.apache.maven.surefire.api.runorder.Priority
- getTriggeredTests() - Method in class org.apache.maven.surefire.junitcore.pc.ShutdownResult
- getType() - Method in enum class org.apache.maven.surefire.booter.ProcessCheckerType
- getTypeEncoded(Object) - Static method in class org.apache.maven.plugin.surefire.booterclient.BooterSerializer
- getTypeEncodedValue(String) - Method in class org.apache.maven.surefire.booter.PropertiesWrapper
-
Retrieves as single object that is persisted with type encoding
- getUnderlying() - Method in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter.EncodingOutputStream
- getUsePhrasedFileName() - Method in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5Xml30StatelessReporter
- getUsePhrasedTestCaseClassName() - Method in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5Xml30StatelessReporter
- getUsePhrasedTestCaseMethodName() - Method in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5Xml30StatelessReporter
- getUsePhrasedTestSuiteClassName() - Method in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5Xml30StatelessReporter
- getUserProperties() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getUseUnlimitedThreads() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getValue() - Method in class org.apache.maven.surefire.api.event.SystemPropertyEvent
- getValue() - Method in class org.apache.maven.surefire.api.util.internal.ImmutableMap.Node
- getVersion() - Method in class org.apache.maven.surefire.api.testset.TestArtifactInfo
- getVersion() - Method in class org.apache.maven.surefire.extensions.StatelessReporter
- getWorkingDirectory() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- getWorkingDirectory() - Method in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- getWorkingDirectory() - Method in class org.apache.maven.plugin.surefire.booterclient.ForkConfiguration
- getWorkingDirectory(int) - Method in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- getWriter(OutputStream) - Static method in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- getXmlReporter() - Method in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- getXmlTag() - Method in enum class org.apache.maven.plugin.surefire.report.ReportEntryType
- getXsdSchemaLocation() - Method in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- getXsdSchemaLocation() - Method in class org.apache.maven.surefire.extensions.StatelessReportMojoConfiguration
- globalStats - Variable in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
- group - Variable in class org.apache.maven.surefire.api.report.CategorizedReportEntry
- GROUP_PREFIX - Static variable in class org.apache.maven.surefire.api.report.CategorizedReportEntry
- GROUP_SUFIX - Static variable in class org.apache.maven.surefire.api.report.CategorizedReportEntry
- groups - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
(TestNG/JUnit47 provider with JUnit4.8+ only and JUnit5+ provider since 2.22.0) Groups/categories/tags for this test.
- groupString(String[], String) - Static method in class org.apache.maven.surefire.testng.TestNGReporter
-
Creates a string out of the list of testng groups in the form of
H
- hadTimeout() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
- handle() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.AcquireNextTestListener
- handle() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.ByeListener
- handle() - Method in interface org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessEventListener
- handle(String) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.ConsoleListener
- handle(String) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.DebugListener
- handle(String) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.WarningListener
- handle(String) - Method in interface org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessStringEventListener
- handle(String, boolean, RunMode, Long) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.StdErrListener
- handle(String, boolean, RunMode, Long) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.StdOutListener
- handle(String, boolean, RunMode, Long) - Method in interface org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessStandardOutErrEventListener
- handle(String, String, RunMode, Long) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.SystemPropertiesListener
- handle(String, String, RunMode, Long) - Method in interface org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessPropertyEventListener
- handle(ReportEntry) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.TestAssumptionFailureListener
- handle(ReportEntry) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.TestErrorListener
- handle(ReportEntry) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.TestFailedListener
- handle(ReportEntry) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.TestSkippedListener
- handle(ReportEntry) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.TestStartingListener
- handle(ReportEntry) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.TestSucceededListener
- handle(StackTraceWriter) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.ErrorListener
- handle(StackTraceWriter) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.ExitErrorEventListener
- handle(StackTraceWriter) - Method in interface org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessExitErrorListener
- handle(StackTraceWriter) - Method in interface org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessStackTraceEventListener
- handle(TestSetReportEntry) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.TestSetCompletedListener
- handle(TestSetReportEntry) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.TestSetStartingListener
- handle(T) - Method in interface org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessReportEventListener
- handleAddError(Object[]) - Method in class org.apache.maven.surefire.junit.TestListenerInvocationHandler
- handleAddFailure(Object[]) - Method in class org.apache.maven.surefire.junit.TestListenerInvocationHandler
- handleEndTest(Object[]) - Method in class org.apache.maven.surefire.junit.TestListenerInvocationHandler
- handleEvent(String) - Method in class org.apache.maven.plugin.surefire.booterclient.output.NativeStdErrStreamConsumer
- handleEvent(String) - Method in class org.apache.maven.plugin.surefire.booterclient.output.NativeStdOutStreamConsumer
- handleEvent(Event) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
- handleEvent(Event) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer
- handleEvent(T) - Method in interface org.apache.maven.surefire.extensions.EventHandler
- handleStartTest(Object[]) - Method in class org.apache.maven.surefire.junit.TestListenerInvocationHandler
- handleSummary(RunResult, Exception) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- handleSummary(RunResult, Exception) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- handleSummary(RunResult, Exception) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- HAS_TEST_ANNOTATION_ON_CLASSPATH - Static variable in class org.apache.maven.surefire.testng.TestNGExecutor
- hasDataType() - Method in enum class org.apache.maven.surefire.api.booter.MasterProcessCommand
- hasDependencyJupiterAPI(Map<String, Artifact>) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnitPlatformProviderInfo
- hasDependencyPlatformEngine(Map<String, Artifact>) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnitPlatformProviderInfo
- hasErrors() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.Pumper
- hasExcludedMethodPatterns - Variable in class org.apache.maven.surefire.api.testset.IncludedExcludedPatterns
- hasExcludedMethodPatterns - Variable in class org.apache.maven.surefire.api.testset.TestListResolver
- hasExcludedMethodPatterns() - Method in interface org.apache.maven.surefire.api.testset.GenericTestPattern
- hasExcludedMethodPatterns() - Method in class org.apache.maven.surefire.api.testset.TestListResolver
- hasExecutedBefore() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- hasFailingTests() - Method in class org.apache.maven.surefire.junitplatform.RunListenerAdapter
- hasFilteredOutAllChildren(Description) - Static method in class org.apache.maven.surefire.junit4.JUnit4Provider
- hasGroupArtifactId(String, String, Artifact) - Static method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- hashCode - Variable in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.Segment
- hashCode() - Method in class org.apache.maven.surefire.api.booter.Command
- hashCode() - Method in class org.apache.maven.surefire.api.report.CategorizedReportEntry
- hashCode() - Method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- hashCode() - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.Segment
- hashCode() - Method in class org.apache.maven.surefire.api.suite.RunResult
- hashCode() - Method in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- hashCode() - Method in class org.apache.maven.surefire.api.testset.TestListResolver
- hashCode() - Method in class org.apache.maven.surefire.api.util.internal.ClassMethod
- hashCode() - Method in class org.apache.maven.surefire.api.util.internal.ImmutableMap.Node
- hashCode() - Method in class org.apache.maven.surefire.booter.Classpath
- hashCode() - Method in class org.apache.maven.surefire.booter.TypeEncodedValue
- hashCode() - Method in class org.apache.maven.surefire.common.junit4.JUnit4Reflector.IgnoredWithUserError
- hashCode() - Method in class org.apache.maven.surefire.common.junit48.RequestedTest
- hashCode() - Method in class org.apache.maven.surefire.junit.TestListenerInvocationHandler.FailedTest
- hashCode() - Method in class org.apache.maven.surefire.junitcore.pc.Scheduler.Controller
- hashCode() - Method in class org.apache.maven.surefire.report.PojoStackTraceWriter
- hasHeader - Variable in class org.apache.maven.surefire.booter.PpidChecker.ProcessInfoConsumer
- hasIncludedMethodPatterns - Variable in class org.apache.maven.surefire.api.testset.IncludedExcludedPatterns
- hasIncludedMethodPatterns - Variable in class org.apache.maven.surefire.api.testset.TestListResolver
- hasIncludedMethodPatterns() - Method in interface org.apache.maven.surefire.api.testset.GenericTestPattern
- hasIncludedMethodPatterns() - Method in class org.apache.maven.surefire.api.testset.TestListResolver
- hasJunit4RunWithAnnotation(Class<?>) - Method in class org.apache.maven.surefire.testng.TestNGDirectoryTestSuite
- hasJunit4TestAnnotation(Class<?>) - Method in class org.apache.maven.surefire.testng.TestNGDirectoryTestSuite
- hasMainModuleDescriptor() - Method in class org.apache.maven.surefire.providerapi.ProviderRequirements
- hasMethodPatterns() - Method in interface org.apache.maven.surefire.api.testset.GenericTestPattern
- hasMethodPatterns() - Method in class org.apache.maven.surefire.api.testset.TestListResolver
- hasNestedExceptions() - Method in exception org.apache.maven.plugin.surefire.booterclient.output.MultipleFailureException
- hasNext() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder.CIt
- hasNext() - Method in class org.apache.maven.surefire.api.util.CloseableIterator
- hasNext() - Method in class org.apache.maven.surefire.booter.CommandReader.ClassesIterator
- hasNext() - Method in class org.apache.maven.surefire.booter.LazyTestsToRun.BlockingIterator
- hasSharedThreadPool() - Method in class org.apache.maven.surefire.junitcore.pc.InvokerStrategy
- hasSharedThreadPool() - Method in class org.apache.maven.surefire.junitcore.pc.NonSharedThreadPoolStrategy
- hasSharedThreadPool() - Method in class org.apache.maven.surefire.junitcore.pc.SchedulingStrategy
- hasSharedThreadPool() - Method in class org.apache.maven.surefire.junitcore.pc.SharedThreadPoolStrategy
- hasSpecificTests() - Method in class org.apache.maven.surefire.testng.TestNGProvider
- hasSuiteXmlFiles() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- hasSuiteXmlFiles() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- hasSuiteXmlFiles() - Method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- hasSuiteXmlFiles() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- hasTestClassPattern() - Method in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- hasTestMethodPattern() - Method in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- hasTestModuleDescriptor() - Method in class org.apache.maven.surefire.providerapi.ProviderRequirements
- hasTestsInProgress() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
- hasThreadCount(JUnitCoreParameters) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerUtil
- hasThreadCounts(JUnitCoreParameters) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerUtil
- hasTimeout() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputer
- hasTimeoutForced() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputer
- hasValidPositions() - Method in exception org.apache.maven.surefire.api.stream.AbstractStreamDecoder.MalformedFrameException
- hasWmicStandardSystemPath() - Static method in class org.apache.maven.surefire.booter.PpidChecker
- haveMethodPatterns(Set<ResolvedTest>) - Static method in class org.apache.maven.surefire.api.testset.TestListResolver
- head - Variable in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder
- HEX - Static variable in class org.apache.maven.plugin.surefire.booterclient.ChecksumCalculator
- highWaterMark - Variable in class org.apache.maven.plugin.surefire.booterclient.ForkNumberBucket
- HOURLY - Static variable in class org.apache.maven.surefire.api.util.RunOrder
I
- IGNORE_PARAMS - Static variable in class org.apache.maven.surefire.common.junit4.JUnit4Reflector
- ignored(RunMode, Long, String, String, String, String, String) - Static method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- IgnoredWithUserError(String) - Constructor for class org.apache.maven.surefire.common.junit4.JUnit4Reflector.IgnoredWithUserError
- immediateCommands - Variable in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream
- immediateCommands - Variable in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder
- ImmediateCommands() - Constructor for class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder.ImmediateCommands
- ImmutableMap<K,
V> - Class in org.apache.maven.surefire.api.util.internal -
Copies input map in
constructor
, and Entries are linked and thread-safe. - ImmutableMap(Map<K, V>) - Constructor for class org.apache.maven.surefire.api.util.internal.ImmutableMap
- ImmutableMap.Node<K,
V> - Class in org.apache.maven.surefire.api.util.internal - IN_MARKER - Static variable in class org.apache.maven.plugin.surefire.report.TestSetStats
- include(Artifact) - Method in class org.apache.maven.plugin.surefire.SurefireDependencyResolver.RuntimeArtifactFilter
- INCLUDE_JUNIT5_ENGINES_PROP - Static variable in class org.apache.maven.surefire.api.booter.ProviderParameterNames
- includeAndExcludeFilters - Variable in class org.apache.maven.surefire.junitplatform.TestPlanScannerFilter
- IncludedExcludedPatterns - Class in org.apache.maven.surefire.api.testset
- IncludedExcludedPatterns() - Constructor for class org.apache.maven.surefire.api.testset.IncludedExcludedPatterns
- includedExcludedTests - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- includedFilters - Variable in class org.apache.maven.surefire.common.junit48.CombinedCategoryFilter
- includedPatterns - Variable in class org.apache.maven.surefire.api.testset.TestListResolver
- includeJUnit5Engines - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
Provide the ID/s of an JUnit engine to be included in the test run.
- includeJUnit5Engines - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
Provide the ID/s of an JUnit engine to be included in the test run.
- includeMethod(IMethodSelectorContext, ITestNGMethod, boolean) - Method in class org.apache.maven.surefire.testng.utils.MethodSelector
- includes - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- includes - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
- includes - Variable in class org.apache.maven.surefire.api.testset.DirectoryScannerParameters
-
Deprecated.
- includes - Variable in class org.apache.maven.surefire.api.util.DefaultDirectoryScanner
-
Deprecated.
- INCLUDES_PROPERTY_PREFIX - Static variable in class org.apache.maven.surefire.booter.BooterConstants
- includesFile - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
A file containing include patterns, each in a next line.
- includesFile - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
A file containing include patterns.
- incompleteTests - Variable in class org.apache.maven.surefire.junitcore.pc.ShutdownResult
- incrementCompletedCount() - Method in class org.apache.maven.plugin.surefire.report.TestSetStats
- incrementFinishedTests(TestReportListener, boolean) - Method in class org.apache.maven.surefire.junitcore.TestSet
-
Deprecated.
- incrementTestMethodCount() - Method in class org.apache.maven.surefire.junitcore.TestSet
-
Deprecated.
- indexClass(String) - Method in class org.apache.maven.surefire.report.ClassMethodIndexer
- indexClassMethod(String, String) - Method in class org.apache.maven.surefire.report.ClassMethodIndexer
- info(String) - Method in interface org.apache.maven.plugin.surefire.log.api.ConsoleLogger
- info(String) - Method in class org.apache.maven.plugin.surefire.log.api.ConsoleLoggerDecorator
- info(String) - Method in class org.apache.maven.plugin.surefire.log.api.NullConsoleLogger
- info(String) - Method in class org.apache.maven.plugin.surefire.log.api.PrintStreamLogger
- info(String) - Method in class org.apache.maven.plugin.surefire.log.PluginConsoleLogger
- info(String) - Method in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
- info(String) - Method in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- info(String) - Method in class org.apache.maven.surefire.api.booter.ForkingRunListener
- info(String) - Method in class org.apache.maven.surefire.junitcore.ConcurrentRunListener
-
Deprecated.
- inForkedVm(String, ClasspathConfiguration, ClassLoaderConfiguration, ProcessCheckerType) - Static method in class org.apache.maven.surefire.booter.StartupConfiguration
- init(File, String) - Method in class org.apache.maven.surefire.api.booter.DumpErrorSingleton
- initDeferred(String) - Static method in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- InPluginProcessDumpSingleton - Class in org.apache.maven.plugin.surefire.booterclient.output
-
Reports errors to dump file.
- InPluginProcessDumpSingleton() - Constructor for class org.apache.maven.plugin.surefire.booterclient.output.InPluginProcessDumpSingleton
- InPluginVMSurefireStarter - Class in org.apache.maven.plugin.surefire
-
Starts the provider in the same VM as the surefire plugin.
- InPluginVMSurefireStarter(StartupConfiguration, ProviderConfiguration, StartupReportConfiguration, ConsoleLogger, Platform) - Constructor for class org.apache.maven.plugin.surefire.InPluginVMSurefireStarter
- inprocClasspath - Variable in class org.apache.maven.surefire.booter.ClasspathConfiguration
-
The surefire classpath to use when invoking in-process with the plugin
- inprocClasspath - Variable in class org.apache.maven.surefire.booter.ModularClasspathConfiguration
-
The surefire classpath to use when invoking in-process with the plugin
- inputStreamCloserHook - Variable in class org.apache.maven.plugin.surefire.booterclient.ForkStarter.CloseableCloser
- insertToQueue(String) - Method in class org.apache.maven.surefire.booter.CommandReader
- insideFork - Variable in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- INSTANCE - Static variable in class org.apache.maven.plugin.surefire.booterclient.ForkNumberBucket
- INSTANCE - Static variable in class org.apache.maven.plugin.surefire.report.NullConsoleOutputReceiver
- INSTANCE - Static variable in class org.apache.maven.plugin.surefire.report.NullConsoleReporter
- INSTANCE - Static variable in class org.apache.maven.plugin.surefire.report.NullFileReporter
- INSTANCE - Static variable in class org.apache.maven.plugin.surefire.report.NullStatelessXmlReporter
- INSTANCE - Static variable in class org.apache.maven.plugin.surefire.report.NullStatisticsReporter
- INSTANCE - Static variable in class org.apache.maven.surefire.testng.utils.FailFastEventsSingleton
- instantiate(ClassLoader, String, Class<T>) - Static method in class org.apache.maven.surefire.api.util.ReflectionUtils
- instantiate(String) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.DynamicProviderInfo
- instantiate(String) - Method in interface org.apache.maven.surefire.providerapi.ConfigurableProviderInfo
- instantiateConsoleOutputFileReporter(Integer) - Method in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- instantiateConsoleReporter(ConsoleLogger) - Method in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- instantiateFileReporter(Integer) - Method in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- instantiateObject(String, Class<?>[], Object[], ClassLoader) - Static method in class org.apache.maven.surefire.api.util.ReflectionUtils
- instantiateOneArg(ClassLoader, String, Class<?>, Object) - Static method in class org.apache.maven.surefire.api.util.ReflectionUtils
- instantiateProvider(String, Object) - Method in class org.apache.maven.surefire.booter.SurefireReflector
- instantiateStatelessXmlReporter(Integer) - Method in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- INT_BINARY - Static variable in class org.apache.maven.surefire.api.stream.AbstractStreamEncoder
- INT_LENGTH - Static variable in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- IntegrationTestMojo - Class in org.apache.maven.plugin.failsafe
-
Run integration tests using Surefire.
- IntegrationTestMojo() - Constructor for class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- interfacesImplementedByDynamicProxy - Variable in class org.apache.maven.surefire.common.junit3.JUnit3Reflector
- interpolateArgLineWithPropertyExpressions() - Method in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
-
Replaces expressions
- INVALID_PROCESS_INFO - Static variable in class org.apache.maven.surefire.booter.ProcessInfo
- InvalidSessionIdException - Exception in org.apache.maven.plugin.surefire.extensions
-
After the authentication has failed,
ForkChannel.tryConnectToClient()
throwsInvalidSessionIdException
andForkStarter
should closeCommandlineExecutor
. - InvalidSessionIdException(String, String) - Constructor for exception org.apache.maven.plugin.surefire.extensions.InvalidSessionIdException
- InvertedFilter - Class in org.apache.maven.surefire.common.junit48
- InvertedFilter(Filter) - Constructor for class org.apache.maven.surefire.common.junit48.InvertedFilter
- invoke(Object) - Method in interface org.apache.maven.surefire.api.provider.SurefireProvider
-
Runs a forked test
- invoke(Object) - Method in class org.apache.maven.surefire.booter.ProviderFactory.ProviderProxy
- invoke(Object) - Method in class org.apache.maven.surefire.junit.JUnit3Provider
- invoke(Object) - Method in class org.apache.maven.surefire.junit4.JUnit4Provider
- invoke(Object) - Method in class org.apache.maven.surefire.junitcore.JUnitCoreProvider
- invoke(Object) - Method in class org.apache.maven.surefire.junitplatform.JUnitPlatformProvider
- invoke(Object) - Method in class org.apache.maven.surefire.testng.TestNGProvider
- invoke(Object, Method, Object[]) - Method in class org.apache.maven.surefire.junit.TestListenerInvocationHandler
- invoke(Object, String) - Method in class org.apache.maven.surefire.testng.conf.AbstractDirectConfigurator.Setter
- INVOKE_EMPTY_PARAMETER_TYPES - Static variable in class org.apache.maven.surefire.booter.ProviderFactory
- INVOKE_EMPTY_PARAMETERS - Static variable in class org.apache.maven.surefire.booter.ProviderFactory
- INVOKE_PARAMETERS - Static variable in class org.apache.maven.surefire.booter.ProviderFactory
- invokeAllTests(TestsToRun, RunListenerAdapter) - Method in class org.apache.maven.surefire.junitplatform.JUnitPlatformProvider
- invokeGetter(Class<?>, Object, String) - Static method in class org.apache.maven.surefire.api.util.ReflectionUtils
- invokeGetter(Object, String) - Static method in class org.apache.maven.surefire.api.util.ReflectionUtils
- invokeMethodChain(Class<?>[], String[], Object) - Static method in class org.apache.maven.surefire.api.util.ReflectionUtils
-
Method chain invoker.
- invokeMethodWithArray(Object, Method, Object...) - Static method in class org.apache.maven.surefire.api.util.ReflectionUtils
- invokeMethodWithArray2(Object, Method, Object...) - Static method in class org.apache.maven.surefire.api.util.ReflectionUtils
- invokeProvider(Object, ClassLoader, Object, ProviderConfiguration, boolean, StartupConfiguration, boolean) - Static method in class org.apache.maven.surefire.booter.ProviderFactory
- invokeReturnedBoolean(String) - Method in class org.apache.maven.plugin.surefire.log.api.ConsoleLoggerDecorator
- InvokerStrategy - Class in org.apache.maven.surefire.junitcore.pc
-
The sequentially executing strategy in private package.
- InvokerStrategy(ConsoleLogger) - Constructor for class org.apache.maven.surefire.junitcore.pc.InvokerStrategy
- invokeSetter(Object, Method, Object) - Static method in class org.apache.maven.surefire.api.util.ReflectionUtils
- invokeSetter(Object, String, Class<?>, Object) - Static method in class org.apache.maven.surefire.api.util.ReflectionUtils
- invokeStaticMethod(Class<?>, String, Class<?>[], Object[]) - Static method in class org.apache.maven.surefire.api.util.ReflectionUtils
-
Invoker of public static no-argument method.
- invokeWithMessage(String, String) - Method in class org.apache.maven.plugin.surefire.log.api.ConsoleLoggerDecorator
- IS_NON_UNIX_FS - Static variable in class org.apache.maven.plugin.surefire.util.ScannerUtil
-
Deprecated.
- is47CompatibleJunitDep() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnitCoreProviderInfo
- isAbstract(Class) - Method in class org.apache.maven.surefire.common.junit48.JUnit48TestChecker
- isAbstractWithEnclosedRunner(Class) - Method in class org.apache.maven.surefire.common.junit48.JUnit48TestChecker
- isAlive - Variable in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer
- isAllParallel() - Method in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- isAllTestsDone() - Method in class org.apache.maven.surefire.junitcore.TestSet
-
Deprecated.
- isAnyConcurrencySelected() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- isAnyGroupsSelected() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- isAnyJunit4(Artifact) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- isApplicable() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.DynamicProviderInfo
- isApplicable() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnit3ProviderInfo
- isApplicable() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnit4ProviderInfo
- isApplicable() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnitCoreProviderInfo
- isApplicable() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnitPlatformProviderInfo
- isApplicable() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.TestNgProviderInfo
- isApplicable() - Method in interface org.apache.maven.surefire.providerapi.ProviderInfo
- isBriefOrPlainFormat() - Method in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- isBuiltInJava9AtLeast() - Static method in class org.apache.maven.surefire.booter.SystemUtils
- isCategoryAnnotationPresent(Class) - Method in class org.apache.maven.surefire.common.junit48.JUnit48Reflector
- isCdataEndBlock(int) - Method in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter.EncodingOutputStream
- isChildDelegation() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- isChildDelegation() - Method in class org.apache.maven.surefire.booter.AbstractPathConfiguration
-
Deprecated.
- isClassPathConfig() - Method in class org.apache.maven.surefire.booter.AbstractPathConfiguration
-
Must be exclusive with
AbstractPathConfiguration.isModularPathConfig()
. - isClassPathConfig() - Method in class org.apache.maven.surefire.booter.ClasspathConfiguration
- isClassPathConfig() - Method in class org.apache.maven.surefire.booter.ModularClasspathConfiguration
- isCliDebugOrShowErrors(List<CommandLineOption>) - Static method in class org.apache.maven.surefire.testng.TestNGExecutor
- isClosed() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream
- isClosed() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestProvidingInputStream
- isClosed() - Method in class org.apache.maven.surefire.api.util.CloseableIterator
- isClosed() - Method in class org.apache.maven.surefire.api.util.TestsToRun.ClassesIterator
- isClosed() - Method in interface org.apache.maven.surefire.extensions.CommandReader
- isConsoleCategory() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.FinalEvent
- isConsoleCategory() - Method in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
- isConsoleCategory() - Method in class org.apache.maven.surefire.api.event.AbstractConsoleEvent
- isConsoleCategory() - Method in class org.apache.maven.surefire.api.event.AbstractStandardStreamEvent
- isConsoleCategory() - Method in class org.apache.maven.surefire.api.event.AbstractTestControlEvent
- isConsoleCategory() - Method in class org.apache.maven.surefire.api.event.ConsoleErrorEvent
- isConsoleCategory() - Method in class org.apache.maven.surefire.api.event.ControlByeEvent
- isConsoleCategory() - Method in class org.apache.maven.surefire.api.event.ControlNextTestEvent
- isConsoleCategory() - Method in class org.apache.maven.surefire.api.event.ControlStopOnNextTestEvent
- isConsoleCategory() - Method in class org.apache.maven.surefire.api.event.Event
- isConsoleCategory() - Method in class org.apache.maven.surefire.api.event.JvmExitErrorEvent
- isConsoleCategory() - Method in class org.apache.maven.surefire.api.event.SystemPropertyEvent
- isConsoleErrorCategory() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.FinalEvent
- isConsoleErrorCategory() - Method in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
- isConsoleErrorCategory() - Method in class org.apache.maven.surefire.api.event.AbstractConsoleEvent
- isConsoleErrorCategory() - Method in class org.apache.maven.surefire.api.event.AbstractStandardStreamEvent
- isConsoleErrorCategory() - Method in class org.apache.maven.surefire.api.event.AbstractTestControlEvent
- isConsoleErrorCategory() - Method in class org.apache.maven.surefire.api.event.ConsoleErrorEvent
- isConsoleErrorCategory() - Method in class org.apache.maven.surefire.api.event.ControlByeEvent
- isConsoleErrorCategory() - Method in class org.apache.maven.surefire.api.event.ControlNextTestEvent
- isConsoleErrorCategory() - Method in class org.apache.maven.surefire.api.event.ControlStopOnNextTestEvent
- isConsoleErrorCategory() - Method in class org.apache.maven.surefire.api.event.Event
- isConsoleErrorCategory() - Method in class org.apache.maven.surefire.api.event.JvmExitErrorEvent
- isConsoleErrorCategory() - Method in class org.apache.maven.surefire.api.event.SystemPropertyEvent
- isControlCategory() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.FinalEvent
- isControlCategory() - Method in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
- isControlCategory() - Method in class org.apache.maven.surefire.api.event.AbstractConsoleEvent
- isControlCategory() - Method in class org.apache.maven.surefire.api.event.AbstractStandardStreamEvent
- isControlCategory() - Method in class org.apache.maven.surefire.api.event.AbstractTestControlEvent
- isControlCategory() - Method in class org.apache.maven.surefire.api.event.ConsoleErrorEvent
- isControlCategory() - Method in class org.apache.maven.surefire.api.event.ControlByeEvent
- isControlCategory() - Method in class org.apache.maven.surefire.api.event.ControlNextTestEvent
- isControlCategory() - Method in class org.apache.maven.surefire.api.event.ControlStopOnNextTestEvent
- isControlCategory() - Method in class org.apache.maven.surefire.api.event.Event
- isControlCategory() - Method in class org.apache.maven.surefire.api.event.JvmExitErrorEvent
- isControlCategory() - Method in class org.apache.maven.surefire.api.event.SystemPropertyEvent
- isDebug - Variable in class org.apache.maven.surefire.booter.ForkedNodeArg
- isDebug() - Method in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- isDebug() - Method in class org.apache.maven.plugin.surefire.booterclient.ForkConfiguration
- isDebugEnabled() - Method in interface org.apache.maven.plugin.surefire.log.api.ConsoleLogger
- isDebugEnabled() - Method in class org.apache.maven.plugin.surefire.log.api.ConsoleLoggerDecorator
- isDebugEnabled() - Method in class org.apache.maven.plugin.surefire.log.api.NullConsoleLogger
- isDebugEnabled() - Method in class org.apache.maven.plugin.surefire.log.api.PrintStreamLogger
- isDebugEnabled() - Method in class org.apache.maven.plugin.surefire.log.PluginConsoleLogger
- isDebugEnabled() - Method in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- isDebugEnabled() - Method in class org.apache.maven.surefire.api.booter.ForkingRunListener
- isDebugEnabled() - Method in class org.apache.maven.surefire.junitcore.ConcurrentRunListener
-
Deprecated.
- isDebugging() - Static method in class org.apache.maven.surefire.booter.ForkedBooter
- isDefaultShutdown() - Method in enum class org.apache.maven.surefire.api.booter.Shutdown
- isDestroyed - Variable in class org.apache.maven.surefire.junitcore.pc.AbstractThreadPoolStrategy
- isDirty - Variable in class org.apache.maven.plugin.surefire.report.Utf8RecodingDeferredFileOutputStream
- isDisable() - Method in class org.apache.maven.surefire.extensions.ConsoleOutputReporter
- isDisable() - Method in class org.apache.maven.surefire.extensions.StatelessReporter
- isDisable() - Method in class org.apache.maven.surefire.extensions.StatelessTestsetInfoReporter
- isDisableXmlReport() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- isElapsedTimeEqual(SimpleReportEntry) - Method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- isEmpty() - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.BufferedStream
- isEmpty() - Method in interface org.apache.maven.surefire.api.testset.GenericTestPattern
- isEmpty() - Method in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- isEmpty() - Method in class org.apache.maven.surefire.api.testset.TestListResolver
- isEmpty() - Method in class org.apache.maven.surefire.api.util.DefaultScanResult
- isEmptyQueue() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.QueueSynchronizer
- isEnableAssertions() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- isEnableAssertions() - Method in class org.apache.maven.surefire.booter.AbstractPathConfiguration
- isEndSymbolAt(int) - Method in class org.apache.maven.surefire.booter.CommandReader.ClassesIterator
- isError() - Method in class org.apache.maven.surefire.booter.ProcessInfo
- isErrorEnabled() - Method in interface org.apache.maven.plugin.surefire.log.api.ConsoleLogger
- isErrorEnabled() - Method in class org.apache.maven.plugin.surefire.log.api.ConsoleLoggerDecorator
- isErrorEnabled() - Method in class org.apache.maven.plugin.surefire.log.api.NullConsoleLogger
- isErrorEnabled() - Method in class org.apache.maven.plugin.surefire.log.api.PrintStreamLogger
- isErrorEnabled() - Method in class org.apache.maven.plugin.surefire.log.PluginConsoleLogger
- isErrorEnabled() - Method in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- isErrorEnabled() - Method in class org.apache.maven.surefire.api.booter.ForkingRunListener
- isErrorEnabled() - Method in class org.apache.maven.surefire.junitcore.ConcurrentRunListener
-
Deprecated.
- isErrorFree() - Method in class org.apache.maven.surefire.api.suite.RunResult
- isErrorInFork() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
- isErrorOrFailure() - Method in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- isExit() - Method in enum class org.apache.maven.surefire.api.booter.Shutdown
- isFailFast() - Method in class org.apache.maven.surefire.common.junit4.Notifier
- isFailFast() - Method in class org.apache.maven.surefire.junit4.JUnit4Provider
- isFailFast() - Method in class org.apache.maven.surefire.junitcore.JUnitCoreProvider
- isFailFast() - Method in class org.apache.maven.surefire.testng.TestNGProvider
- isFailure() - Method in class org.apache.maven.surefire.api.suite.RunResult
- isFailureInsideJUnitItself(Description) - Static method in class org.apache.maven.surefire.common.junit4.JUnit4ProviderUtil
- isFailureOrTimeout() - Method in class org.apache.maven.surefire.api.suite.RunResult
- isFatal(Exception) - Static method in class org.apache.maven.plugin.surefire.SurefireHelper
- isFinished() - Method in class org.apache.maven.surefire.api.util.TestsToRun
- isForking() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- isForkMode - Variable in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- isForkMode() - Method in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- isForkModeNever(String) - Static method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- isForkOnce() - Method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- isIllegalEscape(char) - Static method in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- isIllegalEscape(int) - Static method in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- isInfoEnabled() - Method in interface org.apache.maven.plugin.surefire.log.api.ConsoleLogger
- isInfoEnabled() - Method in class org.apache.maven.plugin.surefire.log.api.ConsoleLoggerDecorator
- isInfoEnabled() - Method in class org.apache.maven.plugin.surefire.log.api.NullConsoleLogger
- isInfoEnabled() - Method in class org.apache.maven.plugin.surefire.log.api.PrintStreamLogger
- isInfoEnabled() - Method in class org.apache.maven.plugin.surefire.log.PluginConsoleLogger
- isInfoEnabled() - Method in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- isInfoEnabled() - Method in class org.apache.maven.surefire.api.booter.ForkingRunListener
- isInfoEnabled() - Method in class org.apache.maven.surefire.junitcore.ConcurrentRunListener
-
Deprecated.
- isInsaneJunitNullString(String) - Static method in class org.apache.maven.surefire.common.junit4.JUnit4ProviderUtil
- isInsideFork() - Method in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- isInsideFork() - Method in interface org.apache.maven.surefire.api.provider.ProviderParameters
- isInSupers(Class<?>, String) - Static method in class org.apache.maven.surefire.report.SmartStackTraceParser
- isInternalError() - Method in class org.apache.maven.surefire.api.suite.RunResult
- isInvalid() - Method in class org.apache.maven.surefire.booter.ProcessInfo
- isJarArtifact(File) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- isJava9AtLeast() - Method in class org.apache.maven.plugin.surefire.JdkAttributes
- isJava9AtLeast(String) - Static method in class org.apache.maven.surefire.booter.SystemUtils
- isJava9AtLeast(BigDecimal) - Static method in class org.apache.maven.surefire.booter.SystemUtils
- isJavaClassFile(String) - Static method in class org.apache.maven.plugin.surefire.util.ScannerUtil
- isJUnit3Available() - Method in class org.apache.maven.surefire.common.junit3.JUnit3Reflector
- isJunit3Test(Class<?>) - Method in class org.apache.maven.surefire.testng.TestNGDirectoryTestSuite
- isJunit47Compatible(Artifact) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- isJUnit48Available() - Method in class org.apache.maven.surefire.common.junit48.JUnit48Reflector
- isJunit4Test(Class<?>) - Method in class org.apache.maven.surefire.testng.TestNGDirectoryTestSuite
- isJUnit4UpgradeCheck() - Static method in class org.apache.maven.surefire.junit4.JUnit4Provider
- isJUnitTest(Class<?>) - Method in class org.apache.maven.surefire.testng.TestNGDirectoryTestSuite
- isJvmError(String) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.BufferedStream
- isJvmExitError() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.FinalEvent
- isJvmExitError() - Method in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
- isJvmExitError() - Method in class org.apache.maven.surefire.api.event.AbstractConsoleEvent
- isJvmExitError() - Method in class org.apache.maven.surefire.api.event.AbstractStandardStreamEvent
- isJvmExitError() - Method in class org.apache.maven.surefire.api.event.AbstractTestControlEvent
- isJvmExitError() - Method in class org.apache.maven.surefire.api.event.ConsoleErrorEvent
- isJvmExitError() - Method in class org.apache.maven.surefire.api.event.ControlByeEvent
- isJvmExitError() - Method in class org.apache.maven.surefire.api.event.ControlNextTestEvent
- isJvmExitError() - Method in class org.apache.maven.surefire.api.event.ControlStopOnNextTestEvent
- isJvmExitError() - Method in class org.apache.maven.surefire.api.event.Event
- isJvmExitError() - Method in class org.apache.maven.surefire.api.event.JvmExitErrorEvent
- isJvmExitError() - Method in class org.apache.maven.surefire.api.event.SystemPropertyEvent
- isKill() - Method in enum class org.apache.maven.surefire.api.booter.Shutdown
- isKnown(String) - Static method in enum class org.apache.maven.surefire.api.booter.Shutdown
- isLeafUnspecified(JUnitCoreParameters) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerUtil
- isMainDescriptor - Variable in class org.apache.maven.surefire.booter.ModularClasspath
- isMainDescriptor() - Method in class org.apache.maven.surefire.booter.ModularClasspath
- isMainModuleDescriptor - Variable in class org.apache.maven.plugin.surefire.ResolvePathResultWrapper
- isMainModuleDescriptor() - Method in class org.apache.maven.plugin.surefire.ResolvePathResultWrapper
- isManifestOnlyJarRequestedAndUsable() - Method in class org.apache.maven.surefire.booter.ClassLoaderConfiguration
- isManifestOnlyJarRequestedAndUsable() - Method in class org.apache.maven.surefire.booter.StartupConfiguration
- isMavenParallel() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- isMessageEqual(SimpleReportEntry) - Method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- isModularPath() - Method in class org.apache.maven.surefire.providerapi.ProviderRequirements
- isModularPathConfig() - Method in class org.apache.maven.surefire.booter.AbstractPathConfiguration
-
Must be exclusive with
AbstractPathConfiguration.isClassPathConfig()
. - isModularPathConfig() - Method in class org.apache.maven.surefire.booter.ClasspathConfiguration
- isModularPathConfig() - Method in class org.apache.maven.surefire.booter.ModularClasspathConfiguration
- isModule(File) - Static method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- isMultiLine(String) - Static method in class org.apache.maven.surefire.report.SmartStackTraceParser
- isMultiLineExceptionMessage(Throwable) - Static method in class org.apache.maven.surefire.api.report.LegacyPojoStackTraceWriter
- isMultiLineExceptionMessage(Throwable) - Static method in class org.apache.maven.surefire.common.junit4.JUnit4StackTraceWriter
- isMultiLineExceptionMessage(Throwable) - Static method in class org.apache.maven.surefire.report.PojoStackTraceWriter
- isNameEqual(SimpleReportEntry) - Method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- isNameTextEqual(SimpleReportEntry) - Method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- isNameWithGroup() - Method in class org.apache.maven.surefire.api.report.CategorizedReportEntry
- isNewLine - Variable in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.BufferedStream
- isNewLine() - Method in interface org.apache.maven.surefire.api.report.OutputReportEntry
- isNewLine() - Method in class org.apache.maven.surefire.api.report.TestOutputReportEntry
- isNoArgsInstanceMethod(Method) - Static method in class org.apache.maven.surefire.junit.PojoTestSetExecutor
- isNotForking() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- isNoThreading() - Method in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- IsolatedClassLoader - Class in org.apache.maven.surefire.booter
-
Loads classes from jar files added via
IsolatedClassLoader.addURL(URL)
. - IsolatedClassLoader(ClassLoader, boolean, String) - Constructor for class org.apache.maven.surefire.booter.IsolatedClassLoader
- isOpen() - Method in class org.apache.maven.surefire.api.util.internal.AbstractNoninterruptibleReadableChannel
- isOpen() - Method in class org.apache.maven.surefire.api.util.internal.AbstractNoninterruptibleWritableChannel
- isOptimized() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- isParallelBoth() - Method in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
-
Deprecated.Instead use the expression isParallelMethods() && isParallelClasses().
- isParallelClasses() - Method in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- isParallelismSelected() - Method in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- isParallelMethods() - Method in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- isParallelMethodsAndTypes() - Method in class org.apache.maven.surefire.junitcore.JUnitCoreProvider
- isParallelOptimization() - Method in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- isParallelOptimized() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- isParallelSuites() - Method in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- isParallelTypes() - Method in class org.apache.maven.surefire.junitcore.JUnitCoreProvider
- isPerCoreThreadCount() - Method in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- isPojoTest(Class<?>) - Method in class org.apache.maven.surefire.junit.PojoAndJUnit3Checker
- isPositiveFilter - Variable in class org.apache.maven.surefire.common.junit48.RequestedTest
- isPrintSummary() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- isPrintSummary() - Method in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- isPrintSummary() - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- isPrintSummary() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- isProcessAlive() - Method in class org.apache.maven.surefire.booter.PpidChecker
-
This method can be called only after
PpidChecker.canUse()
has returnedtrue
. - isProviderMainClass() - Method in class org.apache.maven.surefire.booter.StartupConfiguration
- isQueueFull() - Method in class org.apache.maven.surefire.booter.CommandReader
- isReadTestsFromInStream() - Method in class org.apache.maven.surefire.booter.ProviderConfiguration
- isRedirectTestOutputToFile() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- isRedirectTestOutputToFile() - Method in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- isRegexMinLength(String) - Static method in class org.apache.maven.surefire.api.testset.TestListResolver
- isRegexPrefixedPattern(String) - Static method in class org.apache.maven.surefire.api.testset.TestListResolver
- isRegexTestClassPattern - Variable in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- isRegexTestClassPattern() - Method in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- isRegexTestMethodPattern - Variable in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- isRegexTestMethodPattern() - Method in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- isRequiresRunHistory() - Method in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- isRerunFailingTests() - Method in class org.apache.maven.surefire.junit4.JUnit4Provider
- isRerunFailingTests() - Method in class org.apache.maven.surefire.junitcore.JUnitCoreProvider
- isReuseForks() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- isReuseForks() - Method in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- isReuseForks() - Method in class org.apache.maven.plugin.surefire.booterclient.ForkConfiguration
- isRunModeEqual(SimpleReportEntry) - Method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- isRunResult(Object) - Method in class org.apache.maven.surefire.booter.SurefireReflector
- isRunWithEnclosedRunner(Class) - Method in class org.apache.maven.surefire.common.junit48.JUnit48TestChecker
- isRunWithPresentInClassLoader() - Method in class org.apache.maven.surefire.common.junit4.JUnit4TestChecker
- isSaidGoodBye() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
- isSecurityManagerSupported() - Static method in class org.apache.maven.surefire.api.util.internal.ObjectUtils
- isShadefire() - Method in class org.apache.maven.surefire.booter.StartupConfiguration
- isShutdown() - Method in class org.apache.maven.plugin.surefire.booterclient.Platform
- isSingleThreaded() - Method in class org.apache.maven.surefire.junitcore.JUnitCoreProvider
- isSkip() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- isSkip() - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
- isSkip() - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- isSkip() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- isSkip() - Method in interface org.apache.maven.plugin.surefire.SurefireReportParameters
- isSkipAfterFailure() - Method in class org.apache.maven.surefire.testng.utils.FailFastEventsSingleton
- isSkipExec() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
Deprecated.
- isSkipExec() - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
-
Deprecated.
- isSkipExec() - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- isSkipExec() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- isSkipExec() - Method in interface org.apache.maven.plugin.surefire.SurefireReportParameters
- isSkipExecution() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- isSkipExecution() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- isSkipExecution() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- isSkipITs() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- isSkipITs() - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
- isSkipped() - Method in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- isSkipTests() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- isSkipTests() - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
- isSkipTests() - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- isSkipTests() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- isSkipTests() - Method in interface org.apache.maven.plugin.surefire.SurefireReportParameters
- isSourceEqual(SimpleReportEntry) - Method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- isSourceTextEqual(SimpleReportEntry) - Method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- isSpecificTestSpecified() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- isSplitPool() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- isStackEqual(SimpleReportEntry) - Method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- isStandardStreamCategory() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.FinalEvent
- isStandardStreamCategory() - Method in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
- isStandardStreamCategory() - Method in class org.apache.maven.surefire.api.event.AbstractConsoleEvent
- isStandardStreamCategory() - Method in class org.apache.maven.surefire.api.event.AbstractStandardStreamEvent
- isStandardStreamCategory() - Method in class org.apache.maven.surefire.api.event.AbstractTestControlEvent
- isStandardStreamCategory() - Method in class org.apache.maven.surefire.api.event.ConsoleErrorEvent
- isStandardStreamCategory() - Method in class org.apache.maven.surefire.api.event.ControlByeEvent
- isStandardStreamCategory() - Method in class org.apache.maven.surefire.api.event.ControlNextTestEvent
- isStandardStreamCategory() - Method in class org.apache.maven.surefire.api.event.ControlStopOnNextTestEvent
- isStandardStreamCategory() - Method in class org.apache.maven.surefire.api.event.Event
- isStandardStreamCategory() - Method in class org.apache.maven.surefire.api.event.JvmExitErrorEvent
- isStandardStreamCategory() - Method in class org.apache.maven.surefire.api.event.SystemPropertyEvent
- isStdout - Variable in class org.apache.maven.surefire.api.report.ConsoleOutputCapture.ForwardingPrintStream
- isStdOut - Variable in class org.apache.maven.surefire.api.report.TestOutputReportEntry
- isStdOut() - Method in interface org.apache.maven.surefire.api.report.OutputReportEntry
- isStdOut() - Method in class org.apache.maven.surefire.api.report.TestOutputReportEntry
- isStopped() - Method in class org.apache.maven.surefire.booter.CommandReader
- isStopped() - Method in class org.apache.maven.surefire.booter.PpidChecker
- isSucceeded() - Method in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- isSuiteOnly(Class) - Method in class org.apache.maven.surefire.common.junit3.JUnit3TestChecker
- isSysPropCategory() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.FinalEvent
- isSysPropCategory() - Method in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
- isSysPropCategory() - Method in class org.apache.maven.surefire.api.event.AbstractConsoleEvent
- isSysPropCategory() - Method in class org.apache.maven.surefire.api.event.AbstractStandardStreamEvent
- isSysPropCategory() - Method in class org.apache.maven.surefire.api.event.AbstractTestControlEvent
- isSysPropCategory() - Method in class org.apache.maven.surefire.api.event.ConsoleErrorEvent
- isSysPropCategory() - Method in class org.apache.maven.surefire.api.event.ControlByeEvent
- isSysPropCategory() - Method in class org.apache.maven.surefire.api.event.ControlNextTestEvent
- isSysPropCategory() - Method in class org.apache.maven.surefire.api.event.ControlStopOnNextTestEvent
- isSysPropCategory() - Method in class org.apache.maven.surefire.api.event.Event
- isSysPropCategory() - Method in class org.apache.maven.surefire.api.event.JvmExitErrorEvent
- isSysPropCategory() - Method in class org.apache.maven.surefire.api.event.SystemPropertyEvent
- isSystemPropertiesEqual(SimpleReportEntry) - Method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- isTestCategory() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.FinalEvent
- isTestCategory() - Method in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
- isTestCategory() - Method in class org.apache.maven.surefire.api.event.AbstractConsoleEvent
- isTestCategory() - Method in class org.apache.maven.surefire.api.event.AbstractStandardStreamEvent
- isTestCategory() - Method in class org.apache.maven.surefire.api.event.AbstractTestControlEvent
- isTestCategory() - Method in class org.apache.maven.surefire.api.event.ConsoleErrorEvent
- isTestCategory() - Method in class org.apache.maven.surefire.api.event.ControlByeEvent
- isTestCategory() - Method in class org.apache.maven.surefire.api.event.ControlNextTestEvent
- isTestCategory() - Method in class org.apache.maven.surefire.api.event.ControlStopOnNextTestEvent
- isTestCategory() - Method in class org.apache.maven.surefire.api.event.Event
- isTestCategory() - Method in class org.apache.maven.surefire.api.event.JvmExitErrorEvent
- isTestCategory() - Method in class org.apache.maven.surefire.api.event.SystemPropertyEvent
- isTestFailureIgnore() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- isTestFailureIgnore() - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
- isTestFailureIgnore() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- isTestFailureIgnore() - Method in interface org.apache.maven.plugin.surefire.SurefireReportParameters
- isTestNGXmlTestSuite(TestRequest) - Method in class org.apache.maven.surefire.testng.TestNGProvider
- isTestRunIdEqual(SimpleReportEntry) - Method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- isTestSuite(Class<?>) - Method in class org.apache.maven.surefire.junitcore.ConfigurableParallelComputer
-
Deprecated.
- isThreadSafe(Runner) - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- isTimeBefore(ProcessInfo) - Method in class org.apache.maven.surefire.booter.ProcessInfo
- isTimeEqualTo(ProcessInfo) - Method in class org.apache.maven.surefire.booter.ProcessInfo
- isTimeout() - Method in class org.apache.maven.surefire.api.suite.RunResult
- isTimeoutElapsed() - Method in class org.apache.maven.surefire.junitcore.pc.ShutdownStatus
- isTooFlaky(RunResult, SurefireReportParameters) - Static method in class org.apache.maven.plugin.surefire.SurefireHelper
- isTrimStackTrace() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- isTrimStackTrace() - Method in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- isTrimStackTrace() - Method in class org.apache.maven.surefire.api.report.ReporterConfiguration
-
Indicates if reporting should trim the stack traces.
- isTrimStackTrace() - Method in class org.apache.maven.surefire.extensions.StatelessReportMojoConfiguration
- ISTRIMSTACKTRACE - Static variable in class org.apache.maven.surefire.booter.BooterConstants
- isTypeClass() - Method in class org.apache.maven.surefire.booter.TypeEncodedValue
- isUnusedDescription(Description) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerUtil
- isUseFile() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- isUseFile() - Method in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- isUseFile() - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- isUseFile() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- isUseManifestOnlyJar() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- isUseManifestOnlyJar() - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- isUseManifestOnlyJar() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- isUseManifestOnlyJar() - Method in class org.apache.maven.surefire.booter.ClassLoaderConfiguration
- isUsePhrasedClassNameInRunning() - Method in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5StatelessTestsetInfoReporter
- isUsePhrasedClassNameInTestCaseSummary() - Method in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5StatelessTestsetInfoReporter
- isUsePhrasedFileName() - Method in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5ConsoleOutputReporter
- isUsePhrasedFileName() - Method in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5StatelessTestsetInfoReporter
- isUseSystemClassLoader() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- isUseSystemClassLoader() - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- isUseSystemClassLoader() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- isUseSystemClassLoader() - Method in class org.apache.maven.surefire.booter.ClassLoaderConfiguration
- isUseUnlimitedThreads() - Method in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- isValid(String) - Static method in enum class org.apache.maven.surefire.booter.ProcessCheckerType
- isValidJUnit3Test(Class<?>) - Method in class org.apache.maven.surefire.common.junit3.JUnit3TestChecker
- isValidJUnit4Test(Class) - Method in class org.apache.maven.surefire.common.junit4.JUnit4TestChecker
- isValidTest() - Method in class org.apache.maven.surefire.api.util.internal.ClassMethod
- isValidTestMethod(Method) - Static method in class org.apache.maven.surefire.junit.PojoTestSetExecutor
- isWarnEnabled() - Method in interface org.apache.maven.plugin.surefire.log.api.ConsoleLogger
- isWarnEnabled() - Method in class org.apache.maven.plugin.surefire.log.api.ConsoleLoggerDecorator
- isWarnEnabled() - Method in class org.apache.maven.plugin.surefire.log.api.NullConsoleLogger
- isWarnEnabled() - Method in class org.apache.maven.plugin.surefire.log.api.PrintStreamLogger
- isWarnEnabled() - Method in class org.apache.maven.plugin.surefire.log.PluginConsoleLogger
- isWarnEnabled() - Method in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- isWarnEnabled() - Method in class org.apache.maven.surefire.api.booter.ForkingRunListener
- isWarnEnabled() - Method in class org.apache.maven.surefire.junitcore.ConcurrentRunListener
-
Deprecated.
- isWildcard() - Method in class org.apache.maven.surefire.api.testset.TestListResolver
- isWithinVersionSpec(Artifact, String) - Static method in class org.apache.maven.plugin.surefire.SurefireDependencyResolver
- it - Variable in class org.apache.maven.surefire.api.util.TestsToRun.ClassesIterator
- it - Variable in class org.apache.maven.surefire.booter.LazyTestsToRun.BlockingIterator
- items - Variable in class org.apache.maven.plugin.surefire.SurefireProperties
- iterableCachable - Variable in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder
- iterated() - Method in class org.apache.maven.surefire.api.util.TestsToRun
- iterated() - Method in class org.apache.maven.surefire.booter.CommandReader
- iterated() - Method in class org.apache.maven.surefire.booter.LazyTestsToRun
- iteratedCount - Variable in class org.apache.maven.surefire.api.util.TestsToRun.ClassesIterator
- iteratedCount - Variable in class org.apache.maven.surefire.api.util.TestsToRun
- iteratedCount - Variable in class org.apache.maven.surefire.booter.CommandReader
- iterator() - Method in class org.apache.maven.surefire.api.util.TestsToRun
-
Returns an iterator over the located java.lang.Class objects
- iterator() - Method in class org.apache.maven.surefire.booter.Classpath
- iterator() - Method in class org.apache.maven.surefire.booter.CommandReader.ClassesIterable
- iterator() - Method in class org.apache.maven.surefire.booter.LazyTestsToRun
-
The iterator can be used only in one Thread.
J
- JarManifestForkConfiguration - Class in org.apache.maven.plugin.surefire.booterclient
- JarManifestForkConfiguration(Classpath, File, String, File, Properties, String, Map<String, String>, String[], boolean, int, boolean, Platform, ConsoleLogger, ForkNodeFactory) - Constructor for class org.apache.maven.plugin.surefire.booterclient.JarManifestForkConfiguration
- JarManifestForkConfiguration.ClasspathElementUri - Class in org.apache.maven.plugin.surefire.booterclient
- JAVA_9_MATCHER - Static variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- JAVA_9_MATCHER_OLD_NOTATION - Static variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- JAVA_CLASS_FILE_EXTENSION - Static variable in class org.apache.maven.surefire.api.filter.SpecificTestClassFilter
- JAVA_CLASS_FILE_EXTENSION - Static variable in class org.apache.maven.surefire.api.testset.TestListResolver
- JAVA_CLASS_FILE_EXTENSION - Static variable in class org.apache.maven.surefire.api.util.DefaultDirectoryScanner
-
Deprecated.
- JAVA_FILE_EXTENSION - Static variable in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- JAVA_SOURCE_FILE_EXTENSION - Static variable in class org.apache.maven.surefire.api.util.DefaultDirectoryScanner
-
Deprecated.
- java9AtLeast - Variable in class org.apache.maven.plugin.surefire.JdkAttributes
- JCIP_NOT_THREAD_SAFE - Static variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- jdk - Variable in class org.apache.maven.plugin.surefire.booterclient.Platform
- JdkAttributes - Class in org.apache.maven.plugin.surefire
- JdkAttributes(File, File, boolean) - Constructor for class org.apache.maven.plugin.surefire.JdkAttributes
- JdkAttributes(String, boolean) - Constructor for class org.apache.maven.plugin.surefire.JdkAttributes
- jdkHome - Variable in class org.apache.maven.plugin.surefire.JdkAttributes
- jdkToolchain - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Allow for configuration of the test jvm via maven toolchains.
- JIGSAW_JAVA_VERSION - Static variable in class org.apache.maven.surefire.booter.SystemUtils
- job() - Method in class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel.Bindings
- job() - Method in class org.apache.maven.surefire.extensions.util.CountDownLauncher
- join(String[]) - Static method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- join(Classpath, Classpath) - Static method in class org.apache.maven.surefire.booter.Classpath
- joinFilters(Collection<Filter>, String) - Method in class org.apache.maven.surefire.common.junit48.CombinedCategoryFilter
- jpmsArguments - Variable in class org.apache.maven.surefire.booter.StartupConfiguration
- JUnit3Provider - Class in org.apache.maven.surefire.junit
- JUnit3Provider(ProviderParameters) - Constructor for class org.apache.maven.surefire.junit.JUnit3Provider
- JUnit3ProviderInfo() - Constructor for class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnit3ProviderInfo
- JUnit3Reflector - Class in org.apache.maven.surefire.common.junit3
-
Reflection facade for JUnit3 classes
- JUnit3Reflector(ClassLoader) - Constructor for class org.apache.maven.surefire.common.junit3.JUnit3Reflector
- JUnit3Reporter - Class in org.apache.maven.surefire.junit
-
This implementation of
RunListener
handlesOutputReportEntry
in theoutput receiver
, downcasting toTestOutputReportEntry
, and delegates the report entry to theTestReportListener
. - JUnit3Reporter(TestReportListener<TestOutputReportEntry>) - Constructor for class org.apache.maven.surefire.junit.JUnit3Reporter
- jUnit3TestChecker - Variable in class org.apache.maven.surefire.common.junit4.JUnit4TestChecker
- jUnit3TestChecker - Variable in class org.apache.maven.surefire.junit.JUnit3Provider
- jUnit3TestChecker - Variable in class org.apache.maven.surefire.junit.PojoAndJUnit3Checker
- JUnit3TestChecker - Class in org.apache.maven.surefire.common.junit3
-
Missing tests ? This class is basically a subset of the JUnit4TestChecker, which is tested to boredom and back.
- JUnit3TestChecker(ClassLoader) - Constructor for class org.apache.maven.surefire.common.junit3.JUnit3TestChecker
- jUnit48Reflector - Variable in class org.apache.maven.surefire.junitcore.JUnitCoreProvider
- JUnit48Reflector - Class in org.apache.maven.surefire.common.junit48
- JUnit48Reflector(ClassLoader) - Constructor for class org.apache.maven.surefire.common.junit48.JUnit48Reflector
- JUnit48TestChecker - Class in org.apache.maven.surefire.common.junit48
-
Looks for additional junit48-like features
- JUnit48TestChecker(ClassLoader) - Constructor for class org.apache.maven.surefire.common.junit48.JUnit48TestChecker
- JUnit4Provider - Class in org.apache.maven.surefire.junit4
- JUnit4Provider(ProviderParameters) - Constructor for class org.apache.maven.surefire.junit4.JUnit4Provider
- JUnit4ProviderInfo(Artifact, Artifact) - Constructor for class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnit4ProviderInfo
- JUnit4ProviderUtil - Class in org.apache.maven.surefire.common.junit4
-
Utility method used among all JUnit4 providers
- JUnit4ProviderUtil() - Constructor for class org.apache.maven.surefire.common.junit4.JUnit4ProviderUtil
- JUnit4Reflector - Class in org.apache.maven.surefire.common.junit4
-
JUnit4 reflection helper
- JUnit4Reflector() - Constructor for class org.apache.maven.surefire.common.junit4.JUnit4Reflector
- JUnit4Reflector.IgnoredWithUserError - Class in org.apache.maven.surefire.common.junit4
- JUnit4RunListener - Class in org.apache.maven.surefire.common.junit4
-
RunListener for JUnit4, delegates to our own RunListener
- JUnit4RunListener(TestReportListener<TestOutputReportEntry>) - Constructor for class org.apache.maven.surefire.common.junit4.JUnit4RunListener
-
Constructor.
- JUnit4RunListenerFactory - Class in org.apache.maven.surefire.common.junit4
- JUnit4RunListenerFactory() - Constructor for class org.apache.maven.surefire.common.junit4.JUnit4RunListenerFactory
- JUnit4StackTraceWriter - Class in org.apache.maven.surefire.common.junit4
-
Writes out a specific
Failure
for surefire as a stacktrace. - JUnit4StackTraceWriter(Failure) - Constructor for class org.apache.maven.surefire.common.junit4.JUnit4StackTraceWriter
-
Constructor.
- jUnit4TestChecker - Variable in class org.apache.maven.surefire.common.junit48.JUnit48TestChecker
- jUnit4TestChecker - Variable in class org.apache.maven.surefire.junit4.JUnit4Provider
- JUnit4TestChecker - Class in org.apache.maven.surefire.common.junit4
- JUnit4TestChecker(ClassLoader) - Constructor for class org.apache.maven.surefire.common.junit4.JUnit4TestChecker
- JUnit5ConsoleOutputReporter - Class in org.apache.maven.plugin.surefire.extensions.junit5
-
The extension of
logger
for JUnit5. - JUnit5ConsoleOutputReporter() - Constructor for class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5ConsoleOutputReporter
- JUnit5StatelessTestsetInfoReporter - Class in org.apache.maven.plugin.surefire.extensions.junit5
-
Extension of
file and console reporter of test-set
for JUnit5. - JUnit5StatelessTestsetInfoReporter() - Constructor for class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5StatelessTestsetInfoReporter
- JUnit5Xml30StatelessReporter - Class in org.apache.maven.plugin.surefire.extensions.junit5
-
The extension of
xml reporter
based on XSD version 3.0 for JUnit5. - JUnit5Xml30StatelessReporter() - Constructor for class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5Xml30StatelessReporter
- junitArtifact - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnit4ProviderInfo
- junitArtifact - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnitCoreProviderInfo
- junitArtifactName - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Allows you to specify the name of the JUnit artifact.
- junitClass - Variable in class org.apache.maven.surefire.common.junit3.JUnit3TestChecker
- JUnitCore - Class in org.apache.maven.surefire.junitcore
-
JUnitCore solves bugs in original junit class
JUnitCore
. - JUnitCore() - Constructor for class org.apache.maven.surefire.junitcore.JUnitCoreWrapper.JUnitCore
- JUnitCore(Notifier) - Constructor for class org.apache.maven.surefire.junitcore.JUnitCore
- jUnitCoreParameters - Variable in class org.apache.maven.surefire.junitcore.JUnitCoreProvider
- jUnitCoreParameters - Variable in class org.apache.maven.surefire.junitcore.JUnitCoreWrapper
- JUnitCoreParameters - Class in org.apache.maven.surefire.junitcore
- JUnitCoreParameters(Map<String, String>) - Constructor for class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- JUnitCoreProvider - Class in org.apache.maven.surefire.junitcore
- JUnitCoreProvider(ProviderParameters) - Constructor for class org.apache.maven.surefire.junitcore.JUnitCoreProvider
- JUnitCoreProviderInfo(Artifact, Artifact) - Constructor for class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnitCoreProviderInfo
- JUnitCoreRunListener - Class in org.apache.maven.surefire.junitcore
-
Noteworthy things about JUnit4 listening:
A class that is annotated with @Ignore will have one invocation of "testSkipped" with source==name A method that is annotated with @Ignore will have a invocation of testSkipped with source and name distinct Methods annotated with @Ignore trigger no further events. - JUnitCoreRunListener(ConcurrentRunListener, Map<String, TestSet>) - Constructor for class org.apache.maven.surefire.junitcore.JUnitCoreRunListener
- JUnitCoreWrapper - Class in org.apache.maven.surefire.junitcore
-
Encapsulates access to JUnitCore
- JUnitCoreWrapper(Notifier, JUnitCoreParameters, ConsoleLogger) - Constructor for class org.apache.maven.surefire.junitcore.JUnitCoreWrapper
- JUnitCoreWrapper.JUnitCore - Class in org.apache.maven.surefire.junitcore
- junitDepArtifact - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnit4ProviderInfo
- junitDepArtifact - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnitCoreProviderInfo
- junitFailure - Variable in class org.apache.maven.surefire.common.junit4.JUnit4StackTraceWriter
- junitOptions - Variable in class org.apache.maven.surefire.testng.TestNGDirectoryTestSuite
- junitPlatformArtifact - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnitPlatformProviderInfo
- JUnitPlatformProvider - Class in org.apache.maven.surefire.junitplatform
-
JUnit 5 Platform Provider.
- JUnitPlatformProvider(ProviderParameters) - Constructor for class org.apache.maven.surefire.junitplatform.JUnitPlatformProvider
- JUnitPlatformProvider(ProviderParameters, Launcher) - Constructor for class org.apache.maven.surefire.junitplatform.JUnitPlatformProvider
- JUnitPlatformProviderInfo(Artifact, Artifact, TestClassPath) - Constructor for class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnitPlatformProviderInfo
- junitPlatformRunnerArtifact - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnitPlatformProviderInfo
- junitRunWithAnnotation - Variable in class org.apache.maven.surefire.testng.TestNGDirectoryTestSuite
- junitTestAnnotation - Variable in class org.apache.maven.surefire.testng.TestNGDirectoryTestSuite
- junitTestClass - Variable in class org.apache.maven.surefire.testng.TestNGDirectoryTestSuite
- JUnitTestFailureListener - Class in org.apache.maven.surefire.common.junit4
-
Test listener to record all the failures during one run
- JUnitTestFailureListener() - Constructor for class org.apache.maven.surefire.common.junit4.JUnitTestFailureListener
- JUnitTestSetExecutor - Class in org.apache.maven.surefire.junit
-
JUnit3 test set
- JUnitTestSetExecutor(JUnit3Reflector, JUnit3Reporter) - Constructor for class org.apache.maven.surefire.junit.JUnitTestSetExecutor
- jvm - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Option to specify the jvm (or path to the java executable) to use with the forking options.
- JVM_ERROR_PATTERNS - Static variable in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- jvmExecutable - Variable in class org.apache.maven.plugin.surefire.JdkAttributes
- JvmExitErrorEvent - Class in org.apache.maven.surefire.api.event
-
The event for the JVM exit error.
- JvmExitErrorEvent(StackTraceWriter) - Constructor for class org.apache.maven.surefire.api.event.JvmExitErrorEvent
- jvmRun - Variable in class org.apache.maven.plugin.surefire.booterclient.ForkStarter.CloseableCloser
- jvmTerminator - Variable in class org.apache.maven.surefire.booter.ForkedBooter
K
- key - Variable in class org.apache.maven.surefire.api.event.SystemPropertyEvent
- key - Variable in class org.apache.maven.surefire.api.util.internal.ImmutableMap.Node
- keys() - Method in class org.apache.maven.plugin.surefire.SurefireProperties
- KEYS_THAT_CANNOT_BE_USED_AS_SYSTEM_PROPERTIES - Static variable in class org.apache.maven.plugin.surefire.SurefireProperties
- KeyValueSource - Interface in org.apache.maven.surefire.booter
-
A key-value source obeying the geneal constrains of java.util.Properties
- kill() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
- kill() - Method in class org.apache.maven.surefire.booter.ForkedBooter
- kill(int) - Method in class org.apache.maven.surefire.booter.ForkedBooter
- KILL - Enum constant in enum class org.apache.maven.surefire.api.booter.Shutdown
- killOrphanForks() - Method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
L
- largeCache - Variable in class org.apache.maven.plugin.surefire.report.Utf8RecodingDeferredFileOutputStream
- LAST_DITCH_SHUTDOWN_THREAD - Static variable in class org.apache.maven.surefire.booter.ForkedBooter
- LAST_TEST_SYMBOL - Static variable in class org.apache.maven.surefire.booter.CommandReader
- lastFinishedDescription - Variable in class org.apache.maven.surefire.junitcore.NonConcurrentRunListener
-
Deprecated.
- lastStartAt - Variable in class org.apache.maven.plugin.surefire.report.TestSetStats
- lastStarted - Variable in class org.apache.maven.surefire.junitcore.MethodsParallelRunListener
-
Deprecated.
- launcher - Variable in class org.apache.maven.surefire.junitplatform.JUnitPlatformProvider
- launcher - Variable in class org.apache.maven.surefire.junitplatform.LazyLauncher
- launcher - Variable in class org.apache.maven.surefire.junitplatform.TestPlanScannerFilter
- launcher() - Method in class org.apache.maven.surefire.junitplatform.LazyLauncher
- launcherSession - Variable in class org.apache.maven.surefire.junitplatform.LazyLauncher
- launchLastDitchDaemonShutdownThread(int) - Method in class org.apache.maven.surefire.booter.ForkedBooter
- LazyLauncher - Class in org.apache.maven.surefire.junitplatform
-
Launcher proxy which delays the most possible the initialization of the real JUnit Launcher in order to avoid stream/stdout corruption due to early logging.
- LazyLauncher() - Constructor for class org.apache.maven.surefire.junitplatform.LazyLauncher
- LazyTestsToRun - Class in org.apache.maven.surefire.booter
-
A variant of TestsToRun that is provided with test class names from an
System.in
. - LazyTestsToRun(MasterProcessChannelEncoder, CommandReader) - Constructor for class org.apache.maven.surefire.booter.LazyTestsToRun
-
C'tor
- LazyTestsToRun.BlockingIterator - Class in org.apache.maven.surefire.booter
- LeastFailureComparator() - Constructor for class org.apache.maven.surefire.api.runorder.RunEntryStatisticsMap.LeastFailureComparator
- LegacyForkChannel - Class in org.apache.maven.plugin.surefire.extensions
-
The main purpose of this class is to bind the
command reader
reading the commands fromCommandReader
, serializing them and writing the stream to thesub-process
. - LegacyForkChannel(ForkNodeArguments) - Constructor for class org.apache.maven.plugin.surefire.extensions.LegacyForkChannel
- LegacyForkNodeFactory - Class in org.apache.maven.plugin.surefire.extensions
-
The factory of
LegacyForkChannel
. - LegacyForkNodeFactory() - Constructor for class org.apache.maven.plugin.surefire.extensions.LegacyForkNodeFactory
- LegacyMasterProcessChannelProcessorFactory - Class in org.apache.maven.surefire.booter.spi
-
Producer of encoder and decoder for process pipes.
- LegacyMasterProcessChannelProcessorFactory() - Constructor for class org.apache.maven.surefire.booter.spi.LegacyMasterProcessChannelProcessorFactory
- LegacyPojoStackTraceWriter - Class in org.apache.maven.surefire.api.report
-
Write the trace out for a POJO test.
- LegacyPojoStackTraceWriter(String, String, Throwable) - Constructor for class org.apache.maven.surefire.api.report.LegacyPojoStackTraceWriter
- length - Variable in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.Segment
- Level - Enum Class in org.apache.maven.plugin.surefire.log.api
- Level() - Constructor for enum class org.apache.maven.plugin.surefire.log.api.Level
- line - Variable in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.Memento
- lineBoundSymbolWidth(String) - Static method in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- LineConsumerThread - Class in org.apache.maven.surefire.extensions.util
- LineConsumerThread(String, ReadableByteChannel, EventHandler<String>, CountdownCloseable) - Constructor for class org.apache.maven.surefire.extensions.util.LineConsumerThread
- LineConsumerThread(String, ReadableByteChannel, EventHandler<String>, CountdownCloseable, Charset) - Constructor for class org.apache.maven.surefire.extensions.util.LineConsumerThread
- listeners - Variable in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
- listeners - Variable in class org.apache.maven.surefire.booter.CommandReader
- listeners - Variable in class org.apache.maven.surefire.common.junit4.Notifier
- listenToShutdownCommands(String) - Method in class org.apache.maven.surefire.booter.ForkedBooter
- listParameters() - Static method in enum class org.apache.maven.surefire.api.booter.Shutdown
- lists - Variable in class org.apache.maven.surefire.api.runorder.ThreadedExecutionScheduler
- load(Class<T>, ClassLoader) - Method in class org.apache.maven.surefire.providerapi.ServiceLoader
- loadClass(ClassLoader, String) - Static method in class org.apache.maven.surefire.api.util.DefaultDirectoryScanner
-
Deprecated.
- loadClass(ClassLoader, String) - Static method in class org.apache.maven.surefire.api.util.DefaultScanResult
- loadClass(ClassLoader, String) - Static method in class org.apache.maven.surefire.api.util.ReflectionUtils
- loadClass(String) - Method in class org.apache.maven.surefire.booter.IsolatedClassLoader
- loadClass(String) - Static method in class org.apache.maven.surefire.testng.conf.AbstractDirectConfigurator
- loadListenerClasses(String) - Static method in class org.apache.maven.surefire.testng.conf.AbstractDirectConfigurator
- loadNotThreadSafeAnnotations() - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- loadProperties(File) - Static method in class org.apache.maven.plugin.surefire.SurefireProperties
- loadProperties(File) - Static method in class org.apache.maven.surefire.booter.SystemPropertyManager
- loadProperties(InputStream) - Static method in class org.apache.maven.plugin.surefire.SurefireProperties
- loadProperties(InputStream) - Static method in class org.apache.maven.surefire.booter.SystemPropertyManager
-
Loads the properties, closes the stream
- localHost - Variable in class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel
- localPort - Variable in class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel
- localRepository - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
ArtifactRepository of the localRepository.
- localRepository - Variable in class org.apache.maven.plugin.surefire.SurefireDependencyResolver
- locatedClasses - Variable in class org.apache.maven.surefire.api.util.TestsToRun
- locateTestClasses(ClassLoader, ScannerFilter) - Method in class org.apache.maven.surefire.api.util.DefaultDirectoryScanner
-
Deprecated.
- locateTestClasses(ClassLoader, ScannerFilter) - Method in interface org.apache.maven.surefire.api.util.DirectoryScanner
-
Deprecated.Locates tests based on scanning directories
- locateTestSets() - Method in class org.apache.maven.surefire.testng.TestNGXmlTestSuite
- locationManager - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- lock - Variable in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- lock - Variable in class org.apache.maven.surefire.junitcore.MethodsParallelRunListener
-
Deprecated.
- log - Variable in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- log - Variable in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- log - Variable in class org.apache.maven.plugin.surefire.SurefireDependencyResolver
- log - Variable in class org.apache.maven.surefire.api.report.TestOutputReportEntry
- log(String) - Method in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
- log(String, boolean, boolean, boolean, boolean, boolean) - Method in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
- log(String, Level) - Method in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
- logDebugOrCliShowErrors(String) - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
- logDebugOrCliShowErrors(String) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- logDebugOrCliShowErrors(String, PluginConsoleLogger, Collection<CommandLineOption>) - Static method in class org.apache.maven.plugin.surefire.SurefireHelper
- logger - Variable in class org.apache.maven.plugin.failsafe.VerifyMojo
- logger - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- logger - Variable in class org.apache.maven.plugin.surefire.extensions.StreamFeeder
- logger - Variable in class org.apache.maven.plugin.surefire.log.api.ConsoleLoggerDecorator
- logger - Variable in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- logger - Variable in class org.apache.maven.surefire.booter.CommandReader
- logger - Variable in class org.apache.maven.surefire.booter.ForkedBooter
- logger - Variable in class org.apache.maven.surefire.booter.ForkedNodeArg
- logger - Variable in class org.apache.maven.surefire.extensions.StatelessTestsetInfoConsoleReportEventListener
- logger - Variable in class org.apache.maven.surefire.junitcore.ConcurrentRunListener
-
Deprecated.
- logger - Variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- logger - Variable in class org.apache.maven.surefire.junitcore.pc.Scheduler
- logger - Variable in class org.apache.maven.surefire.junitcore.pc.SchedulingStrategy
- logger - Variable in class org.apache.maven.surefire.junitcore.pc.SingleThreadScheduler
- logger - Variable in class org.apache.maven.surefire.providerapi.ProviderDetector
- LOGGING_LEVEL_DEBUG - Enum constant in enum class org.apache.maven.surefire.api.cli.CommandLineOption
- LOGGING_LEVEL_ERROR - Enum constant in enum class org.apache.maven.surefire.api.cli.CommandLineOption
- LOGGING_LEVEL_INFO - Enum constant in enum class org.apache.maven.surefire.api.cli.CommandLineOption
- LOGGING_LEVEL_WARN - Enum constant in enum class org.apache.maven.surefire.api.cli.CommandLineOption
- LogicalStream - Class in org.apache.maven.surefire.junitcore
-
Deprecated.
- LogicalStream() - Constructor for class org.apache.maven.surefire.junitcore.LogicalStream
-
Deprecated.
- logPrefix - Variable in enum class org.apache.maven.plugin.surefire.report.DefaultReporterFactory.TestResultType
- logQuietly(String) - Method in class org.apache.maven.surefire.junitcore.pc.Scheduler
- logQuietly(Throwable) - Method in class org.apache.maven.surefire.junitcore.pc.Scheduler
- logQuietly(Throwable) - Method in class org.apache.maven.surefire.junitcore.pc.SchedulingStrategy
- logReportsDirectory() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- logsAtEnd - Variable in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- logWarningAtEnd(String) - Method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter.ForkedNodeArg
- logWarningAtEnd(String) - Method in interface org.apache.maven.surefire.api.fork.ForkNodeArguments
- logWarningAtEnd(String) - Method in class org.apache.maven.surefire.booter.ForkedNodeArg
- LONG_LENGTH - Static variable in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- lookForTestAnnotatedMethods(Class) - Method in class org.apache.maven.surefire.common.junit4.JUnit4TestChecker
- lookup(Class<?>, ClassLoader) - Method in class org.apache.maven.surefire.providerapi.ServiceLoader
- lookupAnnotation(String) - Static method in class org.apache.maven.surefire.testng.TestNGDirectoryTestSuite
- lookupClass(String) - Static method in class org.apache.maven.surefire.testng.TestNGDirectoryTestSuite
- lookupDecoderFactory(String) - Static method in class org.apache.maven.surefire.booter.ForkedBooter
- lookupSpiImplementations(Enumeration<URL>) - Static method in class org.apache.maven.surefire.providerapi.ServiceLoader
-
Method loadServices loads the services of a class that are defined using the SPI mechanism.
- lowerCase(String...) - Static method in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
M
- MAGIC_NUMBER_FOR_COMMANDS - Static variable in class org.apache.maven.surefire.api.booter.Constants
- MAGIC_NUMBER_FOR_COMMANDS_BYTES - Static variable in class org.apache.maven.surefire.api.booter.Constants
- MAGIC_NUMBER_FOR_EVENTS - Static variable in class org.apache.maven.surefire.api.booter.Constants
- MAGIC_NUMBER_FOR_EVENTS_BYTES - Static variable in class org.apache.maven.surefire.api.booter.Constants
- main(String[]) - Static method in class org.apache.maven.surefire.booter.ForkedBooter
-
This method is invoked when Surefire is forked - this method parses and organizes the arguments passed to it and then calls the Surefire class' run method.
- MAIN_CLI_OPTIONS - Static variable in class org.apache.maven.surefire.booter.BooterConstants
- mainCliOptions - Variable in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- mainCliOptions - Variable in class org.apache.maven.surefire.booter.ProviderConfiguration
- mainCliOptions - Variable in class org.apache.maven.surefire.testng.TestNGDirectoryTestSuite
- mainCliOptions - Variable in class org.apache.maven.surefire.testng.TestNGProvider
- mainModuleDescriptor - Variable in class org.apache.maven.surefire.providerapi.ProviderRequirements
- makeQueueFull() - Method in class org.apache.maven.surefire.booter.CommandReader
- MalformedChannelException - Exception in org.apache.maven.surefire.api.stream
- MalformedChannelException() - Constructor for exception org.apache.maven.surefire.api.stream.MalformedChannelException
- MalformedFrameException(int, int) - Constructor for exception org.apache.maven.surefire.api.stream.AbstractStreamDecoder.MalformedFrameException
- markStopped() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.QueueSynchronizer
- markTestSetFinished() - Method in class org.apache.maven.surefire.api.util.TestsToRun
- master - Variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- master - Variable in class org.apache.maven.surefire.junitcore.pc.SingleThreadScheduler
- masterController - Variable in class org.apache.maven.surefire.junitcore.pc.Scheduler
- MasterProcessChannelDecoder - Interface in org.apache.maven.surefire.api.booter
-
An abstraction for physical decoder of commands.
- MasterProcessChannelEncoder - Interface in org.apache.maven.surefire.api.booter
-
An abstraction for physical encoder of events.
- MasterProcessChannelProcessorFactory - Interface in org.apache.maven.surefire.spi
-
The SPI interface, a factory of an encoder and a decoder.
- MasterProcessCommand - Enum Class in org.apache.maven.surefire.api.booter
-
Commands which are sent from plugin to the forked jvm.
- MasterProcessCommand(String, Class<?>) - Constructor for enum class org.apache.maven.surefire.api.booter.MasterProcessCommand
- match(String, String) - Method in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- matchAsExclusive(String, String) - Method in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- matchAsInclusive(String, String) - Method in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- matchClass(String) - Method in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- matchClassPatter(String) - Method in class org.apache.maven.surefire.api.testset.ResolvedTest.ClassMatcher
-
Deprecated.
- matchClassRegexPatter(String) - Method in class org.apache.maven.surefire.api.testset.ResolvedTest.ClassMatcher
-
Deprecated.
- matchDescription(Description) - Static method in class org.apache.maven.surefire.common.junit4.MatchDescriptions
- MatchDescriptions - Class in org.apache.maven.surefire.common.junit4
-
Only run test methods in the given failure set.
- MatchDescriptions(Iterable<Description>) - Constructor for class org.apache.maven.surefire.common.junit4.MatchDescriptions
- matches(StackTraceElement) - Method in class org.apache.maven.surefire.report.ClassNameStackTraceFilter
- matches(StackTraceElement) - Method in class org.apache.maven.surefire.report.NullStackTraceFilter
- matches(StackTraceElement) - Method in interface org.apache.maven.surefire.report.StackTraceFilter
- matches(String) - Method in class org.apache.maven.surefire.api.util.RunOrder
- matchMethod(String) - Method in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- matchMethodName(String) - Method in class org.apache.maven.surefire.api.testset.ResolvedTest.MethodMatcher
-
Deprecated.
- matchTestClassFile(String) - Method in class org.apache.maven.surefire.api.testset.ResolvedTest.ClassMatcher
-
Deprecated.
- MAX_PATH_LENGTH_WINDOWS - Static variable in class org.apache.maven.plugin.surefire.SurefireHelper
-
The maximum path that does not require long path prefix on Windows.
Seesun/nio/fs/WindowsPath
in OpenJDK and MSDN article. - maxQueueSize - Variable in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.QueueSynchronizer
- memento - Variable in class org.apache.maven.surefire.booter.spi.CommandChannelDecoder
- Memento() - Constructor for class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.Memento
- mergeFromOtherFactories(Collection<DefaultReporterFactory>) - Method in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
- mergeFromOtherFactories(Collection<DefaultReporterFactory>) - Method in interface org.apache.maven.plugin.surefire.report.ReportsMerger
- mergeIncludedAndExcludedTests(Collection<String>, Collection<String>) - Static method in class org.apache.maven.surefire.api.testset.TestListResolver
- mergeTestHistoryResult() - Method in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
-
Merge all the TestMethodStats in each TestRunListeners and put results into flakyTests, failedTests and errorTests, indexed by test class and method name.
- message - Variable in class org.apache.maven.plugin.surefire.booterclient.output.DeserializedStacktraceWriter
- message - Variable in class org.apache.maven.surefire.api.event.AbstractConsoleEvent
- message - Variable in class org.apache.maven.surefire.api.event.AbstractStandardStreamEvent
- message - Variable in class org.apache.maven.surefire.api.report.SimpleReportEntry
- message - Variable in class org.apache.maven.surefire.booter.spi.EventChannelEncoder.StackTrace
- MESSAGE_ELEMENT - Static variable in class org.apache.maven.plugin.failsafe.util.FailsafeSummaryXmlUtils
- MESSAGE_NIL_ELEMENT - Static variable in class org.apache.maven.plugin.failsafe.util.FailsafeSummaryXmlUtils
- messageTypes - Variable in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- method - Variable in class org.apache.maven.surefire.api.util.internal.ClassMethod
- METHOD - Enum constant in enum class org.apache.maven.surefire.api.testset.ResolvedTest.Type
-
Deprecated.
- methodFilter - Variable in class org.apache.maven.surefire.junit4.TestResolverFilter
- methodFilter - Variable in class org.apache.maven.surefire.testng.TestNGDirectoryTestSuite
- MethodFilter - Class in org.apache.maven.surefire.common.junit48
- MethodFilter(String) - Constructor for class org.apache.maven.surefire.common.junit48.MethodFilter
- MethodFilter(TestListResolver) - Constructor for class org.apache.maven.surefire.common.junit48.MethodFilter
- methodIndex - Variable in class org.apache.maven.surefire.report.ClassMethodIndexer
- methodMatcher - Variable in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- MethodMatcher() - Constructor for class org.apache.maven.surefire.api.testset.ResolvedTest.MethodMatcher
-
Deprecated.
- methodPattern - Variable in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- methods - Variable in class org.apache.maven.surefire.junitcore.pc.Concurrency
- methods - Variable in class org.apache.maven.surefire.junitcore.pc.RunnerCounter
- METHODS - Enum constant in enum class org.apache.maven.surefire.junitcore.pc.Type
- MethodSelector - Class in org.apache.maven.surefire.testng.utils
-
For internal use only
- MethodSelector() - Constructor for class org.apache.maven.surefire.testng.utils.MethodSelector
- MethodsParallelRunListener - Class in org.apache.maven.surefire.junitcore
-
Deprecated.
- MethodsParallelRunListener(Map<String, TestSet>, ReporterFactory, boolean) - Constructor for class org.apache.maven.surefire.junitcore.MethodsParallelRunListener
-
Deprecated.
- minClasses(int, RunnerCounter) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerUtil
- minMethods(int, RunnerCounter) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerUtil
- minSuccessRate - Variable in class org.apache.maven.surefire.api.runorder.Priority
- minSuites(int, RunnerCounter) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerUtil
- minTimeout(long, long) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputer
- MINUTES_TO_MILLIS - Static variable in class org.apache.maven.surefire.booter.PpidChecker
- mkdirs(File) - Static method in class org.apache.maven.surefire.api.util.internal.DumpFileUtils
- modelProperties - Variable in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- modularClasspath - Variable in class org.apache.maven.surefire.booter.ModularClasspathConfiguration
- ModularClasspath - Class in org.apache.maven.surefire.booter
-
Jigsaw class-path and module-path.
- ModularClasspath(String, List<String>, Collection<String>, File, boolean) - Constructor for class org.apache.maven.surefire.booter.ModularClasspath
- ModularClasspathConfiguration - Class in org.apache.maven.surefire.booter
- ModularClasspathConfiguration(ModularClasspath, Classpath, Classpath, Classpath, boolean, boolean) - Constructor for class org.apache.maven.surefire.booter.ModularClasspathConfiguration
- ModularClasspathForkConfiguration - Class in org.apache.maven.plugin.surefire.booterclient
- ModularClasspathForkConfiguration(Classpath, File, String, File, Properties, String, Map<String, String>, String[], boolean, int, boolean, Platform, ConsoleLogger, ForkNodeFactory) - Constructor for class org.apache.maven.plugin.surefire.booterclient.ModularClasspathForkConfiguration
- modularPath - Variable in class org.apache.maven.surefire.providerapi.ProviderRequirements
- moduleNameFromDescriptor - Variable in class org.apache.maven.surefire.booter.ModularClasspath
- modulePath - Variable in class org.apache.maven.surefire.booter.ModularClasspath
- MS_PER_SEC - Static variable in class org.apache.maven.plugin.surefire.report.ReporterUtils
- MultipleFailureException - Exception in org.apache.maven.plugin.surefire.booterclient.output
- MultipleFailureException() - Constructor for exception org.apache.maven.plugin.surefire.booterclient.output.MultipleFailureException
- multiplyByCoreCount(JUnitCoreParameters, double) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerUtil
N
- name - Variable in class org.apache.maven.surefire.api.report.SimpleReportEntry
- name - Variable in class org.apache.maven.surefire.api.util.internal.DaemonThreadFactory.NamedThreadFactory
- name - Variable in class org.apache.maven.surefire.api.util.RunOrder
- name() - Method in class org.apache.maven.surefire.api.util.RunOrder
- NamedThreadFactory(String) - Constructor for class org.apache.maven.surefire.api.util.internal.DaemonThreadFactory.NamedThreadFactory
- namePrefix - Variable in class org.apache.maven.surefire.api.util.internal.DaemonThreadFactory
- names - Variable in class org.apache.maven.plugin.surefire.util.SpecificFileFilter
-
Deprecated.
- names - Variable in class org.apache.maven.surefire.api.filter.SpecificTestClassFilter
- nameText - Variable in class org.apache.maven.surefire.api.report.SimpleReportEntry
- NANOS_IN_A_SECOND - Static variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputer
- nanosToSeconds(long) - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputer
- narrowDependencies(Map<String, Artifact>, Map<String, Artifact>) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnitPlatformProviderInfo
- NATIVE - Enum constant in enum class org.apache.maven.surefire.booter.ProcessCheckerType
- NativeStdErrStreamConsumer - Class in org.apache.maven.plugin.surefire.booterclient.output
-
The standard error logger for the error stream of the forked JMV, see
ForkStarter
. - NativeStdErrStreamConsumer(Object) - Constructor for class org.apache.maven.plugin.surefire.booterclient.output.NativeStdErrStreamConsumer
- NativeStdOutStreamConsumer - Class in org.apache.maven.plugin.surefire.booterclient.output
-
The standard output logger for the output stream of the forked JMV, see org.apache.maven.plugin.surefire.extensions.SurefireForkChannel.
- NativeStdOutStreamConsumer(Object) - Constructor for class org.apache.maven.plugin.surefire.booterclient.output.NativeStdOutStreamConsumer
- nestedClasses - Variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- nestedClassesChildren - Variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- nestedSuites - Variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- newBufferedChannel(InputStream) - Static method in class org.apache.maven.surefire.api.util.internal.Channels
- newBufferedChannel(OutputStream) - Static method in class org.apache.maven.surefire.api.util.internal.Channels
- newChannel(InputStream) - Static method in class org.apache.maven.surefire.api.util.internal.Channels
- newChannel(InputStream, int) - Static method in class org.apache.maven.surefire.api.util.internal.Channels
- newChannel(OutputStream) - Static method in class org.apache.maven.surefire.api.util.internal.Channels
- newChannel(OutputStream, int) - Static method in class org.apache.maven.surefire.api.util.internal.Channels
- newCharsetEncoder() - Method in class org.apache.maven.surefire.api.stream.AbstractStreamEncoder
- newCharsetEncoder() - Method in class org.apache.maven.surefire.booter.stream.EventEncoder
- newCharsetEncoder() - Method in class org.apache.maven.surefire.stream.CommandEncoder
- newConfigurationParameters() - Method in class org.apache.maven.surefire.junitplatform.JUnitPlatformProvider
- newDaemonThread(Runnable) - Static method in class org.apache.maven.surefire.api.util.internal.DaemonThreadFactory
- newDaemonThread(Runnable, String) - Static method in class org.apache.maven.surefire.api.util.internal.DaemonThreadFactory
- newDaemonThreadFactory() - Static method in class org.apache.maven.surefire.api.util.internal.DaemonThreadFactory
-
Should be used by thread pools.
- newDaemonThreadFactory(String) - Static method in class org.apache.maven.surefire.api.util.internal.DaemonThreadFactory
- newDebugSink() - Method in class org.apache.maven.surefire.booter.stream.CommandDecoder
- newDebugSink(ForkNodeArguments) - Method in class org.apache.maven.surefire.stream.EventDecoder
- newDirectorySuite() - Method in class org.apache.maven.surefire.testng.TestNGProvider
- newDumpFile(File) - Static method in class org.apache.maven.plugin.surefire.booterclient.output.InPluginProcessDumpSingleton
- newDumpFile(File, int) - Static method in class org.apache.maven.plugin.surefire.booterclient.output.InPluginProcessDumpSingleton
- newDumpFile(File, String) - Static method in class org.apache.maven.surefire.api.util.internal.DumpFileUtils
-
New dump file.
- newDumpStreamFile(File) - Method in class org.apache.maven.plugin.surefire.booterclient.output.InPluginProcessDumpSingleton
- newDumpStreamFile(File, int) - Static method in class org.apache.maven.plugin.surefire.booterclient.output.InPluginProcessDumpSingleton
- newFilters() - Method in class org.apache.maven.surefire.junitplatform.JUnitPlatformProvider
- newFormattedDateFileName() - Static method in class org.apache.maven.surefire.api.util.internal.DumpFileUtils
- newInputStream(AsynchronousByteChannel) - Static method in class org.apache.maven.surefire.api.util.internal.Channels
- newInstance(Constructor<?>, Object...) - Static method in class org.apache.maven.surefire.api.util.ReflectionUtils
- newJvmArgLine(int) - Method in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- newLine - Variable in class org.apache.maven.surefire.api.report.TestOutputReportEntry
- newOutputStream(AsynchronousByteChannel) - Static method in class org.apache.maven.surefire.api.util.internal.Channels
- newPool() - Static method in class org.apache.maven.surefire.junitcore.pc.SingleThreadScheduler
- newReportEntry(RunMode, long, String, String, String, String, String, String, Integer, String, String, String) - Static method in class org.apache.maven.surefire.stream.EventDecoder
- newResults - Variable in class org.apache.maven.plugin.surefire.runorder.StatisticsReporter
- newRunnerScheduler() - Method in class org.apache.maven.surefire.junitcore.pc.SingleThreadScheduler
- newShutdownHandler() - Method in class org.apache.maven.surefire.junitcore.pc.Scheduler
- newStartupConfigWithClasspath(ClassLoaderConfiguration, ProviderInfo, TestClassPath) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- newStartupConfigWithModularPath(ClassLoaderConfiguration, ProviderInfo, ResolvePathResultWrapper, DefaultScanResult, String, TestClassPath) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- newTestClassPriority(String) - Static method in class org.apache.maven.surefire.api.runorder.Priority
-
Returns a priority that applies to a new testclass (that has never been run/recorded)
- newTestListResolver(Set<ResolvedTest>, Set<ResolvedTest>) - Static method in class org.apache.maven.surefire.api.testset.TestListResolver
- newThread(Runnable) - Method in class org.apache.maven.surefire.api.util.internal.DaemonThreadFactory.NamedThreadFactory
- newThread(Runnable) - Method in class org.apache.maven.surefire.api.util.internal.DaemonThreadFactory
- newWeakIterator() - Method in class org.apache.maven.surefire.api.util.TestsToRun
- newWeakIterator() - Method in class org.apache.maven.surefire.booter.LazyTestsToRun
- newXmlClassInstance(String, int) - Static method in class org.apache.maven.surefire.testng.TestNGExecutor
- newXmlSuite() - Method in class org.apache.maven.surefire.testng.TestNGProvider
- next - Variable in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder.Node
- next - Variable in class org.apache.maven.surefire.api.util.internal.ImmutableMap.Node
- next() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder.CIt
- next() - Method in class org.apache.maven.surefire.api.util.CloseableIterator
- next() - Method in class org.apache.maven.surefire.booter.CommandReader.ClassesIterator
- next() - Method in class org.apache.maven.surefire.booter.LazyTestsToRun.BlockingIterator
- nextCachedNode(TestLessInputStream.TestLessInputStreamBuilder.Node) - Static method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder
- nextCommand() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.DefaultCommandReader
- nextCommand() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream
- nextCommand() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestProvidingInputStream
- nextCommandNotifier - Variable in class org.apache.maven.surefire.booter.CommandReader
- nextGeneration(int) - Method in class org.apache.maven.surefire.api.runorder.RunEntryStatistics
- nextGenerationFailure(int) - Method in class org.apache.maven.surefire.api.runorder.RunEntryStatistics
- nextQueueIndex - Variable in class org.apache.maven.surefire.booter.CommandReader.ClassesIterator
- nextSegmentType(MT) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- nextSegmentType(ForkedProcessEventType) - Method in class org.apache.maven.surefire.stream.EventDecoder
- nextSegmentType(MasterProcessCommand) - Method in class org.apache.maven.surefire.booter.stream.CommandDecoder
- NL - Static variable in class org.apache.maven.surefire.api.util.internal.StringUtils
- NL_BYTES - Static variable in class org.apache.maven.plugin.surefire.report.Utf8RecodingDeferredFileOutputStream
- NO_COLOR - Enum constant in enum class org.apache.maven.plugin.surefire.log.api.Level
-
direct println
- NO_POSITION - Static variable in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- NO_POSITION - Static variable in class org.apache.maven.surefire.booter.stream.CommandDecoder
- NO_POSITION - Static variable in class org.apache.maven.surefire.stream.EventDecoder
- NO_TESTS - Static variable in class org.apache.maven.surefire.api.suite.RunResult
- node - Variable in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder.CIt
- Node(K, V) - Constructor for class org.apache.maven.surefire.api.util.internal.ImmutableMap.Node
- Node(Command) - Constructor for class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder.Node
- nonAbstractClassFilter - Variable in class org.apache.maven.surefire.common.junit3.JUnit3TestChecker
- nonAbstractClassFilter - Variable in class org.apache.maven.surefire.common.junit4.JUnit4TestChecker
- nonAbstractClassFilter - Variable in class org.apache.maven.surefire.common.junit48.JUnit48TestChecker
- nonAbstractClassFilter - Variable in class org.apache.maven.surefire.junit.PojoAndJUnit3Checker
- NonAbstractClassFilter - Class in org.apache.maven.surefire.api.filter
- NonAbstractClassFilter() - Constructor for class org.apache.maven.surefire.api.filter.NonAbstractClassFilter
- nonBlockers - Variable in class org.apache.maven.surefire.junitcore.ConfigurableParallelComputer
-
Deprecated.
- NonConcurrentRunListener - Class in org.apache.maven.surefire.junitcore
-
Deprecated.
- NonConcurrentRunListener(TestReportListener<TestOutputReportEntry>) - Constructor for class org.apache.maven.surefire.junitcore.NonConcurrentRunListener
-
Deprecated.
- NONE - Enum constant in enum class org.apache.maven.plugin.surefire.AbstractSurefireMojo.PluginFailureReason
- nonNull(String) - Static method in class org.apache.maven.surefire.api.stream.AbstractStreamEncoder
- nonRegexClassAndMethods(String, String, boolean, IncludedExcludedPatterns, Collection<ResolvedTest>, Collection<ResolvedTest>) - Static method in class org.apache.maven.surefire.api.testset.TestListResolver
- NonSharedThreadPoolStrategy - Class in org.apache.maven.surefire.junitcore.pc
-
Parallel strategy for non-shared thread pool in private package.
- NonSharedThreadPoolStrategy(ConsoleLogger, ExecutorService) - Constructor for class org.apache.maven.surefire.junitcore.pc.NonSharedThreadPoolStrategy
- noop() - Method in interface org.apache.maven.plugin.surefire.booterclient.lazytestprovider.NotifiableTestStream
- noop() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream
- noop() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder.CachableCommands
- noop() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder.ImmediateCommands
- noop() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestProvidingInputStream
- NOOP - Enum constant in enum class org.apache.maven.surefire.api.booter.MasterProcessCommand
-
To tell a forked process that the master process is still alive.
- NOOP - Static variable in class org.apache.maven.surefire.api.booter.Command
- NORMAL_RUN - Enum constant in enum class org.apache.maven.surefire.api.report.RunMode
- noTestsRun() - Static method in class org.apache.maven.surefire.api.suite.RunResult
- notifiableTestStream - Variable in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
- NotifiableTestStream - Interface in org.apache.maven.plugin.surefire.booterclient.lazytestprovider
-
Remote interface of forked JVM with command methods.
- notifier - Variable in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
- notifier - Variable in class org.apache.maven.surefire.junitcore.JUnitCore
- notifier - Variable in class org.apache.maven.surefire.junitcore.JUnitCoreWrapper
- Notifier - Class in org.apache.maven.surefire.common.junit4
-
Extends
JUnit notifier
, encapsulates several different types ofJUnit listeners
, and fires events to listeners. - Notifier() - Constructor for class org.apache.maven.surefire.common.junit4.Notifier
- Notifier(JUnit4RunListener, int) - Constructor for class org.apache.maven.surefire.common.junit4.Notifier
- notifyEvent(Event) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessEventNotifier
- notifyStreamsToSkipTests(Collection<? extends NotifiableTestStream>) - Static method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- notParallelRunners - Variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- notThreadSafeTests - Variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- NULL_SINGLETON - Static variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- NullBalancer - Class in org.apache.maven.surefire.junitcore.pc
-
This balancer implements
Balancer
and does not do anything -no blocking operation. - NullBalancer() - Constructor for class org.apache.maven.surefire.junitcore.pc.NullBalancer
- NullConsoleLogger - Class in org.apache.maven.plugin.surefire.log.api
-
Logger doing nothing rather than using null.
- NullConsoleLogger() - Constructor for class org.apache.maven.plugin.surefire.log.api.NullConsoleLogger
- NullConsoleOutputReceiver - Class in org.apache.maven.plugin.surefire.report
-
TestcycleConsoleOutputReceiver doing nothing rather than using null.
- NullConsoleOutputReceiver() - Constructor for class org.apache.maven.plugin.surefire.report.NullConsoleOutputReceiver
- NullConsoleReporter - Class in org.apache.maven.plugin.surefire.report
-
ConsoleReporter doing nothing rather than using null.
- NullConsoleReporter() - Constructor for class org.apache.maven.plugin.surefire.report.NullConsoleReporter
- NullFileReporter - Class in org.apache.maven.plugin.surefire.report
-
FileReporter doing nothing rather than using null.
- NullFileReporter() - Constructor for class org.apache.maven.plugin.surefire.report.NullFileReporter
- NullOutputStream() - Constructor for class org.apache.maven.surefire.api.report.ConsoleOutputCapture.NullOutputStream
- NullStackTraceFilter - Class in org.apache.maven.surefire.report
-
always returns true
- NullStackTraceFilter() - Constructor for class org.apache.maven.surefire.report.NullStackTraceFilter
- NullStatelessXmlReporter - Class in org.apache.maven.plugin.surefire.report
-
FileReporter doing nothing rather than using null.
- NullStatelessXmlReporter() - Constructor for class org.apache.maven.plugin.surefire.report.NullStatelessXmlReporter
- NullStatisticsReporter - Class in org.apache.maven.plugin.surefire.report
-
StatisticsReporter doing nothing rather than using null.
- NullStatisticsReporter() - Constructor for class org.apache.maven.plugin.surefire.report.NullStatisticsReporter
- numberOfCompletedChildren - Variable in class org.apache.maven.surefire.junitcore.TestSet
-
Deprecated.
- numberOfTests - Variable in class org.apache.maven.surefire.junitcore.TestSet
-
Deprecated.
- numPermits - Variable in class org.apache.maven.surefire.junitcore.pc.ThreadResourcesBalancer
- numThreads - Variable in class org.apache.maven.surefire.api.runorder.ThreadedExecutionScheduler
O
- objectFactory - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
(TestNG only) Define the factory class used to create all test instances.
- ObjectUtils - Class in org.apache.maven.surefire.api.util.internal
-
Similar to Java 7 java.util.Objects.
- ObjectUtils() - Constructor for class org.apache.maven.surefire.api.util.internal.ObjectUtils
- of(String...) - Method in class org.apache.maven.surefire.api.testset.ResolvedTest.ClassMatcher
-
Deprecated.
- ofDataAt(int) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.Memento
- offline - Variable in class org.apache.maven.plugin.surefire.SurefireDependencyResolver
- onConfigurationFailure(ITestResult) - Method in class org.apache.maven.surefire.testng.TestNGReporter
- onConfigurationSkip(ITestResult) - Method in class org.apache.maven.surefire.testng.TestNGReporter
- onConfigurationSuccess(ITestResult) - Method in class org.apache.maven.surefire.testng.TestNGReporter
- onExit - Variable in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- onFinish(ISuite) - Method in class org.apache.maven.surefire.testng.TestNGReporter
- onFinish(ITestContext) - Method in class org.apache.maven.surefire.testng.TestNGReporter
- onFinish(ITestContext) - Method in class org.apache.maven.surefire.testng.utils.FailFastListener
- onJvmExit() - Method in interface org.apache.maven.surefire.api.booter.MasterProcessChannelEncoder
-
Called on JVM exit error.
- onJvmExit() - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- onlyThreadCount() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- onStart(ISuite) - Method in class org.apache.maven.surefire.testng.TestNGReporter
- onStart(ITestContext) - Method in class org.apache.maven.surefire.testng.TestNGReporter
- onStart(ITestContext) - Method in class org.apache.maven.surefire.testng.utils.FailFastListener
- onTestFailedButWithinSuccessPercentage(ITestResult) - Method in class org.apache.maven.surefire.testng.TestNGReporter
- onTestFailedButWithinSuccessPercentage(ITestResult) - Method in class org.apache.maven.surefire.testng.utils.FailFastListener
- onTestFailure(ITestResult) - Method in class org.apache.maven.surefire.testng.TestNGReporter
- onTestFailure(ITestResult) - Method in class org.apache.maven.surefire.testng.utils.FailFastListener
- onTestSkipped(ITestResult) - Method in class org.apache.maven.surefire.testng.TestNGReporter
- onTestSkipped(ITestResult) - Method in class org.apache.maven.surefire.testng.utils.FailFastListener
- onTestStart(ITestResult) - Method in class org.apache.maven.surefire.testng.TestNGReporter
- onTestStart(ITestResult) - Method in class org.apache.maven.surefire.testng.utils.FailFastListener
- onTestSuccess(ITestResult) - Method in class org.apache.maven.surefire.testng.TestNGReporter
- onTestSuccess(ITestResult) - Method in class org.apache.maven.surefire.testng.utils.FailFastListener
- opcode - Variable in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
- opcode - Variable in enum class org.apache.maven.surefire.api.booter.MasterProcessCommand
- opcodeBinary - Variable in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
- opcodeBinary - Variable in enum class org.apache.maven.surefire.api.booter.MasterProcessCommand
- open - Variable in class org.apache.maven.surefire.api.util.internal.AbstractNoninterruptibleReadableChannel
- open - Variable in class org.apache.maven.surefire.api.util.internal.AbstractNoninterruptibleWritableChannel
- OPEN - Static variable in class org.apache.maven.plugin.surefire.report.ConsoleOutputFileReporter
- optimize - Variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- optimize(boolean) - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- optionallyWildcardFilter(TestListResolver) - Static method in class org.apache.maven.surefire.api.testset.TestListResolver
- options - Variable in class org.apache.maven.surefire.testng.TestNGDirectoryTestSuite
- options - Variable in class org.apache.maven.surefire.testng.TestNGXmlTestSuite
- or(TestListResolver) - Method in class org.apache.maven.surefire.api.testset.TestListResolver
- orderProviderArtifacts(Set<Artifact>) - Static method in class org.apache.maven.plugin.surefire.SurefireDependencyResolver
- orderTestClasses(List<Class<?>>, RunOrder) - Method in class org.apache.maven.surefire.api.util.DefaultRunOrderCalculator
- orderTestClasses(TestsToRun) - Method in class org.apache.maven.surefire.api.util.DefaultRunOrderCalculator
- orderTestClasses(TestsToRun) - Method in interface org.apache.maven.surefire.api.util.RunOrderCalculator
- OrFilter - Class in org.apache.maven.surefire.common.junit48
- OrFilter(Filter[]) - Constructor for class org.apache.maven.surefire.common.junit48.OrFilter
- org.apache.maven.plugin.failsafe - package org.apache.maven.plugin.failsafe
-
Provides Mojo goals for running integration tests and subsequently failing the build in a safe way.
- org.apache.maven.plugin.failsafe.util - package org.apache.maven.plugin.failsafe.util
- org.apache.maven.plugin.surefire - package org.apache.maven.plugin.surefire
- org.apache.maven.plugin.surefire.booterclient - package org.apache.maven.plugin.surefire.booterclient
- org.apache.maven.plugin.surefire.booterclient.lazytestprovider - package org.apache.maven.plugin.surefire.booterclient.lazytestprovider
- org.apache.maven.plugin.surefire.booterclient.output - package org.apache.maven.plugin.surefire.booterclient.output
- org.apache.maven.plugin.surefire.extensions - package org.apache.maven.plugin.surefire.extensions
- org.apache.maven.plugin.surefire.extensions.junit5 - package org.apache.maven.plugin.surefire.extensions.junit5
- org.apache.maven.plugin.surefire.log - package org.apache.maven.plugin.surefire.log
- org.apache.maven.plugin.surefire.log.api - package org.apache.maven.plugin.surefire.log.api
- org.apache.maven.plugin.surefire.report - package org.apache.maven.plugin.surefire.report
- org.apache.maven.plugin.surefire.runorder - package org.apache.maven.plugin.surefire.runorder
- org.apache.maven.plugin.surefire.util - package org.apache.maven.plugin.surefire.util
- org.apache.maven.surefire.api.booter - package org.apache.maven.surefire.api.booter
- org.apache.maven.surefire.api.cli - package org.apache.maven.surefire.api.cli
- org.apache.maven.surefire.api.event - package org.apache.maven.surefire.api.event
- org.apache.maven.surefire.api.filter - package org.apache.maven.surefire.api.filter
- org.apache.maven.surefire.api.fork - package org.apache.maven.surefire.api.fork
- org.apache.maven.surefire.api.provider - package org.apache.maven.surefire.api.provider
- org.apache.maven.surefire.api.report - package org.apache.maven.surefire.api.report
- org.apache.maven.surefire.api.runorder - package org.apache.maven.surefire.api.runorder
- org.apache.maven.surefire.api.stream - package org.apache.maven.surefire.api.stream
- org.apache.maven.surefire.api.suite - package org.apache.maven.surefire.api.suite
- org.apache.maven.surefire.api.testset - package org.apache.maven.surefire.api.testset
- org.apache.maven.surefire.api.util - package org.apache.maven.surefire.api.util
- org.apache.maven.surefire.api.util.internal - package org.apache.maven.surefire.api.util.internal
- org.apache.maven.surefire.booter - package org.apache.maven.surefire.booter
- org.apache.maven.surefire.booter.spi - package org.apache.maven.surefire.booter.spi
- org.apache.maven.surefire.booter.stream - package org.apache.maven.surefire.booter.stream
- org.apache.maven.surefire.common.junit3 - package org.apache.maven.surefire.common.junit3
- org.apache.maven.surefire.common.junit4 - package org.apache.maven.surefire.common.junit4
- org.apache.maven.surefire.common.junit48 - package org.apache.maven.surefire.common.junit48
- org.apache.maven.surefire.extensions - package org.apache.maven.surefire.extensions
- org.apache.maven.surefire.extensions.util - package org.apache.maven.surefire.extensions.util
- org.apache.maven.surefire.junit - package org.apache.maven.surefire.junit
- org.apache.maven.surefire.junit4 - package org.apache.maven.surefire.junit4
- org.apache.maven.surefire.junitcore - package org.apache.maven.surefire.junitcore
- org.apache.maven.surefire.junitcore.pc - package org.apache.maven.surefire.junitcore.pc
- org.apache.maven.surefire.junitplatform - package org.apache.maven.surefire.junitplatform
- org.apache.maven.surefire.providerapi - package org.apache.maven.surefire.providerapi
- org.apache.maven.surefire.report - package org.apache.maven.surefire.report
- org.apache.maven.surefire.spi - package org.apache.maven.surefire.spi
- org.apache.maven.surefire.stream - package org.apache.maven.surefire.stream
- org.apache.maven.surefire.testng - package org.apache.maven.surefire.testng
- org.apache.maven.surefire.testng.conf - package org.apache.maven.surefire.testng.conf
- org.apache.maven.surefire.testng.utils - package org.apache.maven.surefire.testng.utils
- original - Variable in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- originalSystemErr - Variable in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- originalSystemOut - Variable in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- out - Variable in class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel
- out - Variable in class org.apache.maven.plugin.surefire.report.DirectConsoleOutput
- out - Variable in class org.apache.maven.surefire.api.stream.AbstractStreamEncoder
- out - Variable in class org.apache.maven.surefire.stream.CommandEncoder
- output - Variable in class org.apache.maven.surefire.junitcore.LogicalStream
-
Deprecated.
- output - Variable in class org.apache.maven.surefire.junitcore.TestMethod
-
Deprecated.
- OutputReportEntry - Interface in org.apache.maven.surefire.api.report
-
Minimum data requirement for report entry.
- outStreamLock - Variable in class org.apache.maven.plugin.surefire.booterclient.output.NativeStdOutStreamConsumer
- OVERFLOW - Enum constant in enum class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.StreamReadStatus
- overrideAvailableProcessors(int) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerUtil
P
- p1 - Variable in class org.apache.maven.surefire.api.booter.BiProperty
- p2 - Variable in class org.apache.maven.surefire.api.booter.BiProperty
- PACKAGE_DELIMITER - Static variable in class org.apache.maven.plugin.surefire.util.Relocator
- packages - Variable in class org.apache.maven.surefire.booter.ModularClasspath
- parallel - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
(TestNG provider) When you use the parameter
parallel
, TestNG will try to run all your test methods in separate threads, except for methods that depend on each other, which will be run in the same thread in order to respect their order of execution. - parallel - Variable in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- parallel(int, Type) - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- parallel(Type) - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- PARALLEL_KEY - Static variable in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- PARALLEL_OPTIMIZE_KEY - Static variable in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- PARALLEL_OPTIMIZE_PROP - Static variable in class org.apache.maven.surefire.api.booter.ProviderParameterNames
- PARALLEL_PROP - Static variable in class org.apache.maven.surefire.api.booter.ProviderParameterNames
- PARALLEL_TIMEOUT_KEY - Static variable in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- PARALLEL_TIMEOUT_PROP - Static variable in class org.apache.maven.surefire.api.booter.ProviderParameterNames
- PARALLEL_TIMEOUTFORCED_KEY - Static variable in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- PARALLEL_TIMEOUTFORCED_PROP - Static variable in class org.apache.maven.surefire.api.booter.ProviderParameterNames
- parallelClasses() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- parallelClasses(int) - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- ParallelComputer - Class in org.apache.maven.surefire.junitcore.pc
-
ParallelComputer extends JUnit
Computer
and has a shutdown functionality. - ParallelComputer(double, double) - Constructor for class org.apache.maven.surefire.junitcore.pc.ParallelComputer
- ParallelComputerBuilder - Class in org.apache.maven.surefire.junitcore.pc
- ParallelComputerBuilder(ConsoleLogger) - Constructor for class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- ParallelComputerBuilder(ConsoleLogger, JUnitCoreParameters) - Constructor for class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- ParallelComputerBuilder.PC - Class in org.apache.maven.surefire.junitcore.pc
- ParallelComputerBuilder.PC.SuiteFilter - Class in org.apache.maven.surefire.junitcore.pc
- ParallelComputerUtil - Class in org.apache.maven.surefire.junitcore.pc
-
An algorithm which configures
ParallelComputer
with allocated thread resources by givenJUnitCoreParameters
. - ParallelComputerUtil() - Constructor for class org.apache.maven.surefire.junitcore.pc.ParallelComputerUtil
- parallelGroups - Variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- parallelize(Runner, RunnerScheduler) - Method in class org.apache.maven.surefire.junitcore.ConfigurableParallelComputer
-
Deprecated.
- parallelMavenExecution - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Parallel Maven Execution.
- parallelMethods() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- parallelMethods(int) - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- parallelOptimization - Variable in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- parallelOptimized - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
(JUnit 4.7 / provider only) The thread counts do not exceed the number of parallel suite, class runners and average number of methods per class if set to true.
- parallelSuites() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- parallelSuites(int) - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- parallelTestsTimeoutForcedInSeconds - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
Stop executing queued parallel JUnit tests and interrupt currently running tests after a certain number of seconds.
- parallelTestsTimeoutForcedInSeconds - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
Stop executing queued parallel JUnit tests and
interrupt
currently running tests after a certain number of seconds. - parallelTestsTimeoutForcedInSeconds - Variable in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- parallelTestsTimeoutForcedInSeconds() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- parallelTestsTimeoutInSeconds - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
Stop executing queued parallel JUnit tests after a certain number of seconds.
- parallelTestsTimeoutInSeconds - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
Stop executing queued parallel JUnit tests after a certain number of seconds.
- parallelTestsTimeoutInSeconds - Variable in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- parallelTestsTimeoutInSeconds() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- param - Variable in enum class org.apache.maven.surefire.api.booter.Shutdown
- paramClass - Variable in class org.apache.maven.surefire.testng.conf.AbstractDirectConfigurator.Setter
- parameterOf(String) - Static method in enum class org.apache.maven.surefire.api.booter.Shutdown
- parameters - Variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- parameters - Variable in class org.apache.maven.surefire.junitplatform.JUnitPlatformProvider
- PARAMS - Static variable in class org.apache.maven.surefire.common.junit4.JUnit4Reflector
- PARAMS_WITH_ANNOTATIONS - Static variable in class org.apache.maven.surefire.common.junit4.JUnit4Reflector
- parent - Variable in class org.apache.maven.surefire.booter.IsolatedClassLoader
- parentProcessInfo - Variable in class org.apache.maven.surefire.booter.PpidChecker
- patchFile - Variable in class org.apache.maven.surefire.booter.ModularClasspath
- PC() - Constructor for class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- perCoreThreadCount - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
(JUnit 4.7 provider) Indicates that threadCount, threadCountSuites, threadCountClasses, threadCountMethods are per cpu core.
- perCoreThreadCount - Variable in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- PERCORETHREADCOUNT_KEY - Static variable in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- phrasedClassName - Variable in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- phrasedFileName - Variable in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- phrasedMethodName - Variable in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- phrasedSuiteName - Variable in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- pid - Variable in class org.apache.maven.surefire.booter.ProcessInfo
- pid() - Static method in class org.apache.maven.surefire.booter.SystemUtils
- pidJob() - Static method in class org.apache.maven.plugin.surefire.booterclient.Platform
- pidOnJava9() - Static method in class org.apache.maven.surefire.booter.SystemUtils
- pidOnJMX() - Static method in class org.apache.maven.surefire.booter.SystemUtils
- pidStatusOnBSD() - Static method in class org.apache.maven.surefire.booter.SystemUtils
-
The process status.
- pidStatusOnBSD(String) - Static method in class org.apache.maven.surefire.booter.SystemUtils
-
For testing purposes only.
- pidStatusOnLinux() - Static method in class org.apache.maven.surefire.booter.SystemUtils
-
$ cat /proc/self/stat
48982 (cat) R 9744 48982 9744 34818 48982 8192 185 0 0 0 0 0 0 0 20 0 1 0 137436614 103354368 134 18446744073709551615 4194304 4235780 140737488346592 140737488343784 252896458544 0 0 0 0 0 0 0 17 2 0 0 0 0 0
$ SELF_PID=$(cat /proc/self/stat)
$ echo $CPU_ID | gawk '{print $1}'
48982 - pidStatusOnLinux(String) - Static method in class org.apache.maven.surefire.booter.SystemUtils
-
For testing purposes only.
- PING - Enum constant in enum class org.apache.maven.surefire.booter.ProcessCheckerType
- PING_IN_SECONDS - Static variable in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- PING_THREAD - Static variable in class org.apache.maven.surefire.booter.ForkedBooter
- PING_TIMEOUT_IN_SECONDS - Static variable in class org.apache.maven.surefire.booter.ForkedBooter
- pingScheduler - Variable in class org.apache.maven.surefire.booter.ForkedBooter
- pingScheduler - Variable in class org.apache.maven.surefire.booter.ForkedBooter.PingScheduler
- PingScheduler(ScheduledExecutorService, ScheduledExecutorService, PpidChecker) - Constructor for class org.apache.maven.surefire.booter.ForkedBooter.PingScheduler
- pingThreadScheduler - Variable in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- PLAIN - Static variable in class org.apache.maven.plugin.surefire.report.ConsoleReporter
- plainFormat - Variable in class org.apache.maven.plugin.surefire.report.TestSetStats
- platform - Variable in class org.apache.maven.plugin.surefire.InPluginVMSurefireStarter
- Platform - Class in org.apache.maven.plugin.surefire.booterclient
-
Loads platform specifics.
- Platform() - Constructor for class org.apache.maven.plugin.surefire.booterclient.Platform
- Platform(RunnableFuture<Long>, JdkAttributes) - Constructor for class org.apache.maven.plugin.surefire.booterclient.Platform
- PLATFORM - Static variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- platformClassLoader() - Static method in class org.apache.maven.surefire.booter.SystemUtils
- played - Variable in class org.apache.maven.surefire.junitcore.TestSet
-
Deprecated.
- plexusLogger - Variable in class org.apache.maven.plugin.surefire.log.PluginConsoleLogger
- PLUGIN_PID - Static variable in class org.apache.maven.surefire.booter.BooterConstants
- pluginArtifactMap - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Map of plugin artifacts.
- PluginConsoleLogger - Class in org.apache.maven.plugin.surefire.log
-
Wrapper logger of miscellaneous implementations of
Logger
. - PluginConsoleLogger(Logger) - Constructor for class org.apache.maven.plugin.surefire.log.PluginConsoleLogger
- pluginDescriptor - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Information about this plugin, mainly used to lookup this plugin's configuration from the currently executing project.
- PluginFailureReason() - Constructor for enum class org.apache.maven.plugin.surefire.AbstractSurefireMojo.PluginFailureReason
- pluginName - Variable in class org.apache.maven.plugin.surefire.SurefireDependencyResolver
- pluginPidJob - Variable in class org.apache.maven.plugin.surefire.booterclient.Platform
- pluginPlatform - Variable in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- pluginRemoteRepositories - Variable in class org.apache.maven.plugin.surefire.SurefireDependencyResolver
- PojoAndJUnit3Checker - Class in org.apache.maven.surefire.junit
- PojoAndJUnit3Checker(JUnit3TestChecker) - Constructor for class org.apache.maven.surefire.junit.PojoAndJUnit3Checker
- PojoStackTraceWriter - Class in org.apache.maven.surefire.report
-
Write the trace out for a POJO test.
- PojoStackTraceWriter(String, String, Throwable) - Constructor for class org.apache.maven.surefire.report.PojoStackTraceWriter
- PojoTestSetExecutor - Class in org.apache.maven.surefire.junit
-
Executes a JUnit3 test class
- PojoTestSetExecutor(JUnit3Reporter) - Constructor for class org.apache.maven.surefire.junit.PojoTestSetExecutor
- PojoTestSetExecutor.DiscoveredTestMethods - Class in org.apache.maven.surefire.junit
- pool - Variable in class org.apache.maven.surefire.junitcore.pc.SingleThreadScheduler
- POOL_NUMBER - Static variable in class org.apache.maven.surefire.api.util.internal.DaemonThreadFactory
- poolCapacity - Variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- poolHandler - Variable in class org.apache.maven.surefire.junitcore.pc.Scheduler.ShutdownHandler
- popMarker() - Method in class org.apache.maven.surefire.api.util.CloseableIterator
- populateChildrenFromSuites() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- popUnread() - Method in class org.apache.maven.surefire.booter.CommandReader.ClassesIterator
- positionByteBuffer - Variable in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.BufferedStream
- postConfigure(TestNG, String, TestNGReporter, File, int, int) - Static method in class org.apache.maven.surefire.testng.TestNGExecutor
- ppid - Variable in class org.apache.maven.surefire.booter.PpidChecker
- PpidChecker - Class in org.apache.maven.surefire.booter
-
Recognizes PID of Plugin process and determines lifetime.
- PpidChecker(String) - Constructor for class org.apache.maven.surefire.booter.PpidChecker
- PpidChecker.ProcessInfoConsumer - Class in org.apache.maven.surefire.booter
-
Reads standard output from
Process
. - print(boolean) - Method in class org.apache.maven.surefire.api.report.ConsoleOutputCapture.ForwardingPrintStream
- print(char) - Method in class org.apache.maven.surefire.api.report.ConsoleOutputCapture.ForwardingPrintStream
- print(char[]) - Method in class org.apache.maven.surefire.api.report.ConsoleOutputCapture.ForwardingPrintStream
- print(double) - Method in class org.apache.maven.surefire.api.report.ConsoleOutputCapture.ForwardingPrintStream
- print(float) - Method in class org.apache.maven.surefire.api.report.ConsoleOutputCapture.ForwardingPrintStream
- print(int) - Method in class org.apache.maven.surefire.api.report.ConsoleOutputCapture.ForwardingPrintStream
- print(long) - Method in class org.apache.maven.surefire.api.report.ConsoleOutputCapture.ForwardingPrintStream
- print(Object) - Method in class org.apache.maven.surefire.api.report.ConsoleOutputCapture.ForwardingPrintStream
- print(String) - Method in class org.apache.maven.surefire.api.report.ConsoleOutputCapture.ForwardingPrintStream
- PRINTABLE_JVM_NATIVE_STREAM - Static variable in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- printCorruptedStream(AbstractStreamDecoder.Memento) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- printDefaultSeedIfNecessary() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- printExistingLine() - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.BufferedStream
- println() - Method in class org.apache.maven.surefire.api.report.ConsoleOutputCapture.ForwardingPrintStream
- println(boolean) - Method in class org.apache.maven.surefire.api.report.ConsoleOutputCapture.ForwardingPrintStream
- println(char) - Method in class org.apache.maven.surefire.api.report.ConsoleOutputCapture.ForwardingPrintStream
- println(char[]) - Method in class org.apache.maven.surefire.api.report.ConsoleOutputCapture.ForwardingPrintStream
- println(double) - Method in class org.apache.maven.surefire.api.report.ConsoleOutputCapture.ForwardingPrintStream
- println(float) - Method in class org.apache.maven.surefire.api.report.ConsoleOutputCapture.ForwardingPrintStream
- println(int) - Method in class org.apache.maven.surefire.api.report.ConsoleOutputCapture.ForwardingPrintStream
- println(long) - Method in class org.apache.maven.surefire.api.report.ConsoleOutputCapture.ForwardingPrintStream
- println(Object) - Method in class org.apache.maven.surefire.api.report.ConsoleOutputCapture.ForwardingPrintStream
- println(String) - Method in class org.apache.maven.surefire.api.report.ConsoleOutputCapture.ForwardingPrintStream
- println(String, Level) - Method in class org.apache.maven.plugin.surefire.report.ConsoleReporter
- printRemainingStream(AbstractStreamDecoder.Memento) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
-
Print the last string which has not been finished by a new line character.
- printShutdownHook(Collection<String>, Collection<String>, Future<ShutdownResult>) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputer
- PrintStreamLogger - Class in org.apache.maven.plugin.surefire.log.api
-
Console logger for
PrintStream
. - PrintStreamLogger(PrintStream) - Constructor for class org.apache.maven.plugin.surefire.log.api.PrintStreamLogger
- printSummary - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
Option to print summary of test suites or just print the test cases that have errors.
- printSummary - Variable in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- printSummary - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
Option to print summary of test suites or just print the test cases that have errors.
- printTestFailures(DefaultReporterFactory.TestResultType) - Method in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
-
Print failed tests and flaked tests.
- PrioritizedTest - Class in org.apache.maven.surefire.api.runorder
- PrioritizedTest(Class<?>, Priority) - Constructor for class org.apache.maven.surefire.api.runorder.PrioritizedTest
- PrioritizedTestComparator() - Constructor for class org.apache.maven.surefire.api.runorder.RunEntryStatisticsMap.PrioritizedTestComparator
- priority - Variable in class org.apache.maven.surefire.api.runorder.PrioritizedTest
- priority - Variable in class org.apache.maven.surefire.api.runorder.Priority
- Priority - Class in org.apache.maven.surefire.api.runorder
- Priority(String) - Constructor for class org.apache.maven.surefire.api.runorder.Priority
- PROC_STATUS_PID_FIRST_CHARS - Static variable in class org.apache.maven.surefire.booter.SystemUtils
- process - Variable in class org.apache.maven.surefire.extensions.util.CommandlineExecutor
- process - Variable in class org.apache.maven.surefire.extensions.util.CommandlineExecutor.ProcessHook
- PROCESS_CHECKER - Static variable in class org.apache.maven.surefire.booter.BooterConstants
- PROCESS_CHECKER_THREAD - Static variable in class org.apache.maven.surefire.booter.ForkedBooter
- PROCESS_PIPES_ERROR - Static variable in class org.apache.maven.surefire.booter.ForkedBooter
- processChecker - Variable in class org.apache.maven.surefire.booter.ForkedBooter.PingScheduler
- processChecker - Variable in class org.apache.maven.surefire.booter.StartupConfiguration
- processCheckerJob(ForkedBooter.PingScheduler) - Method in class org.apache.maven.surefire.booter.ForkedBooter
- processCheckerScheduler - Variable in class org.apache.maven.surefire.booter.ForkedBooter.PingScheduler
- ProcessCheckerType - Enum Class in org.apache.maven.surefire.booter
- ProcessCheckerType(String) - Constructor for enum class org.apache.maven.surefire.booter.ProcessCheckerType
- ProcessHook(Process) - Constructor for class org.apache.maven.surefire.extensions.util.CommandlineExecutor.ProcessHook
- processIncludesExcludes(List<String>) - Static method in class org.apache.maven.surefire.api.util.DefaultDirectoryScanner
-
Deprecated.
- ProcessInfo - Class in org.apache.maven.surefire.booter
-
Immutable object which encapsulates PID and elapsed time (Unix) or start time (Windows).
- ProcessInfo(String, long) - Constructor for class org.apache.maven.surefire.booter.ProcessInfo
- ProcessInfoConsumer(String) - Constructor for class org.apache.maven.surefire.booter.PpidChecker.ProcessInfoConsumer
- project - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
The Maven Project Object.
- projectArtifactMap - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Map of project artifacts.
- projectBuildDirectory - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Read-only parameter with value of Maven property project.build.directory.
- projectRemoteRepositories - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- projectRemoteRepositories - Variable in class org.apache.maven.plugin.surefire.SurefireDependencyResolver
- properties - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
List of properties for configuring all TestNG related configurations.
- properties - Variable in class org.apache.maven.surefire.booter.BooterDeserializer
- properties - Variable in class org.apache.maven.surefire.booter.PropertiesWrapper
- propertiesThatCannotBeSetASystemProperties() - Method in class org.apache.maven.plugin.surefire.SurefireProperties
- PropertiesWrapper - Class in org.apache.maven.surefire.booter
- PropertiesWrapper(Map<String, String>) - Constructor for class org.apache.maven.surefire.booter.PropertiesWrapper
- property(Map<String, String>, String, boolean) - Static method in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- property(Map<String, String>, String, double) - Static method in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- property(Map<String, String>, String, int) - Static method in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- property(Map<String, String>, String, String) - Static method in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- propertyEventListener - Variable in class org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessEventNotifier
- provideNewTest() - Method in interface org.apache.maven.plugin.surefire.booterclient.lazytestprovider.NotifiableTestStream
-
Forked jvm notifies master process to provide a new test.
- provideNewTest() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream
- provideNewTest() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder.CachableCommands
- provideNewTest() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder.ImmediateCommands
- provideNewTest() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestProvidingInputStream
-
Signal that a new test is to be provided.
- PROVIDER_CLASSPATH_ORDER - Static variable in class org.apache.maven.plugin.surefire.SurefireDependencyResolver
- PROVIDER_CONFIGURATION - Static variable in class org.apache.maven.surefire.booter.BooterConstants
- PROVIDER_DEP_AID - Static variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnitPlatformProviderInfo
- PROVIDER_DEP_GID - Static variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnitPlatformProviderInfo
- PROVIDER_GROUP_ID - Static variable in class org.apache.maven.plugin.surefire.SurefireDependencyResolver
- providerClassName - Variable in class org.apache.maven.surefire.booter.StartupConfiguration
- providerConfig - Variable in class org.apache.maven.plugin.surefire.InPluginVMSurefireStarter
- providerConfiguration - Variable in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- providerConfiguration - Variable in class org.apache.maven.surefire.booter.ForkedBooter
- providerConfiguration - Variable in class org.apache.maven.surefire.booter.ProviderFactory
- ProviderConfiguration - Class in org.apache.maven.surefire.booter
-
Represents the surefire configuration that passes all the way into the provider classloader and the provider.
- ProviderConfiguration(DirectoryScannerParameters, RunOrderParameters, ReporterConfiguration, TestArtifactInfo, TestRequest, Map<String, String>, TypeEncodedValue, boolean, List<CommandLineOption>, int, Shutdown, Integer) - Constructor for class org.apache.maven.surefire.booter.ProviderConfiguration
- providerDetector - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- ProviderDetector - Class in org.apache.maven.surefire.providerapi
- ProviderDetector() - Constructor for class org.apache.maven.surefire.providerapi.ProviderDetector
- ProviderFactory - Class in org.apache.maven.surefire.booter
-
Creates the surefire provider.
- ProviderFactory(StartupConfiguration, ProviderConfiguration, ClassLoader, Object) - Constructor for class org.apache.maven.surefire.booter.ProviderFactory
- ProviderFactory.ProviderProxy - Class in org.apache.maven.surefire.booter
- ProviderInfo - Interface in org.apache.maven.surefire.providerapi
- providerInOtherClassLoader - Variable in class org.apache.maven.surefire.booter.ProviderFactory.ProviderProxy
- providerName - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.DynamicProviderInfo
- ProviderParameterNames - Class in org.apache.maven.surefire.api.booter
- ProviderParameterNames() - Constructor for class org.apache.maven.surefire.api.booter.ProviderParameterNames
- providerParameters - Variable in class org.apache.maven.surefire.junit.JUnit3Provider
- providerParameters - Variable in class org.apache.maven.surefire.junit4.JUnit4Provider
- providerParameters - Variable in class org.apache.maven.surefire.junitcore.JUnitCoreProvider
- providerParameters - Variable in class org.apache.maven.surefire.testng.TestNGProvider
- ProviderParameters - Interface in org.apache.maven.surefire.api.provider
-
Injected into the providers upon provider construction.
- providerProperties - Variable in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- providerProperties - Variable in class org.apache.maven.surefire.booter.ProviderConfiguration
- providerProperties - Variable in class org.apache.maven.surefire.testng.TestNGProvider
- ProviderProxy(Object, ClassLoader) - Constructor for class org.apache.maven.surefire.booter.ProviderFactory.ProviderProxy
- ProviderRequirements - Class in org.apache.maven.surefire.providerapi
-
Used to get additional provider-specific JVM arguments.
- ProviderRequirements(boolean, boolean, boolean) - Constructor for class org.apache.maven.surefire.providerapi.ProviderRequirements
- PS_ETIME_HEADER - Static variable in class org.apache.maven.surefire.booter.PpidChecker
- PS_PID_HEADER - Static variable in class org.apache.maven.surefire.booter.PpidChecker
- pumper - Variable in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer
- Pumper(EventHandler<Event>) - Constructor for class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.Pumper
- pureNotifier() - Static method in class org.apache.maven.surefire.common.junit4.Notifier
- pushNext(T) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.QueueSynchronizer
- put(Object, Object) - Method in class org.apache.maven.plugin.surefire.SurefireProperties
- putAll(Map<?, ?>) - Method in class org.apache.maven.plugin.surefire.SurefireProperties
Q
- qFree - Variable in class org.apache.maven.plugin.surefire.booterclient.ForkNumberBucket
- queue - Variable in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.QueueSynchronizer
- QUEUE_MAX_ITEMS - Static variable in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer
- queueSize - Variable in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.QueueSynchronizer
- QueueSynchronizer(int, T) - Constructor for class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.QueueSynchronizer
R
- random - Variable in class org.apache.maven.surefire.api.util.DefaultRunOrderCalculator
- RANDOM - Static variable in class org.apache.maven.surefire.api.util.RunOrder
- REACTOR_FAIL_AT_END - Enum constant in enum class org.apache.maven.surefire.api.cli.CommandLineOption
- REACTOR_FAIL_FAST - Enum constant in enum class org.apache.maven.surefire.api.cli.CommandLineOption
- REACTOR_FAIL_NEVER - Enum constant in enum class org.apache.maven.surefire.api.cli.CommandLineOption
- read(ByteBuffer) - Method in class org.apache.maven.surefire.api.util.internal.AbstractNoninterruptibleReadableChannel
- read(ByteBuffer, int, int) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- read(AbstractStreamDecoder.Memento, int) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- readByte(AbstractStreamDecoder.Memento) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- readCharset(AbstractStreamDecoder.Memento) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- readFrom - Variable in exception org.apache.maven.surefire.api.stream.AbstractStreamDecoder.MalformedFrameException
- readFrom() - Method in exception org.apache.maven.surefire.api.stream.AbstractStreamDecoder.MalformedFrameException
- readImpl(ByteBuffer) - Method in class org.apache.maven.surefire.api.util.internal.AbstractNoninterruptibleReadableChannel
- readInt(AbstractStreamDecoder.Memento) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- readInteger(AbstractStreamDecoder.Memento) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- readListFromFile(File) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- readLong(AbstractStreamDecoder.Memento) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- readLongPrivate(AbstractStreamDecoder.Memento) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- readMessageType(AbstractStreamDecoder.Memento) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- readNextCommand() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.DefaultCommandReader
-
Used by single thread in StreamFeeder class.
- readNextCommand() - Method in interface org.apache.maven.surefire.extensions.CommandReader
-
Waits for the next command and returns it.
- readSegment(AbstractStreamDecoder.Memento) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- readString(AbstractStreamDecoder.Memento) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- readString(AbstractStreamDecoder.Memento, int) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- readSummary(File) - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
- readTestsFromInStream - Variable in class org.apache.maven.surefire.booter.ProviderConfiguration
- readTo - Variable in exception org.apache.maven.surefire.api.stream.AbstractStreamDecoder.MalformedFrameException
- readTo() - Method in exception org.apache.maven.surefire.api.stream.AbstractStreamDecoder.MalformedFrameException
- redirectTestOutputToFile - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Set this to "true" to redirect the unit test standard output to a file (found in reportsDirectory/testName-output.txt).
- redirectTestOutputToFile - Variable in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- reflectClassLoader(Class<?>, String) - Static method in class org.apache.maven.surefire.booter.SystemUtils
- ReflectionUtils - Class in org.apache.maven.surefire.api.util
- ReflectionUtils() - Constructor for class org.apache.maven.surefire.api.util.ReflectionUtils
- reflector - Variable in class org.apache.maven.surefire.junit.JUnit3Provider
- reflector - Variable in class org.apache.maven.surefire.junit.JUnitTestSetExecutor
- reformatClassPattern(String, boolean) - Static method in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- register(Scheduler) - Method in class org.apache.maven.surefire.junitcore.pc.Scheduler
- registerLauncherDiscoveryListeners(LauncherDiscoveryListener...) - Method in class org.apache.maven.surefire.junitplatform.LazyLauncher
- registerPleaseStopJUnitListener(Notifier) - Method in class org.apache.maven.surefire.junit4.JUnit4Provider
- registerPleaseStopJUnitListener(Notifier) - Method in class org.apache.maven.surefire.junitcore.JUnitCoreProvider
- registerPleaseStopListener() - Method in class org.apache.maven.surefire.testng.TestNGProvider
- registerShutdownListener(TestsToRun) - Method in class org.apache.maven.surefire.junit4.JUnit4Provider
- registerShutdownListener(TestsToRun) - Method in class org.apache.maven.surefire.junitcore.JUnitCoreProvider
- registerShutdownListener(TestsToRun) - Method in class org.apache.maven.surefire.testng.TestNGProvider
- registerTestExecutionListeners(TestExecutionListener...) - Method in class org.apache.maven.surefire.junitplatform.LazyLauncher
- rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class org.apache.maven.surefire.junitcore.pc.Scheduler.ShutdownHandler
- relative(String) - Static method in class org.apache.maven.plugin.surefire.booterclient.JarManifestForkConfiguration.ClasspathElementUri
- RELATIVE_PATH_TO_WMIC - Static variable in class org.apache.maven.surefire.booter.PpidChecker
- relativize(Path, Path) - Static method in class org.apache.maven.plugin.surefire.booterclient.JarManifestForkConfiguration
- release() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder.CachableCommands
- release() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.QueueSynchronizer.SyncT1
- releaseAllPermits() - Method in interface org.apache.maven.surefire.junitcore.pc.Balancer
- releaseAllPermits() - Method in class org.apache.maven.surefire.junitcore.pc.NullBalancer
- releaseAllPermits() - Method in class org.apache.maven.surefire.junitcore.pc.ThreadResourcesBalancer
- releasePermit() - Method in interface org.apache.maven.surefire.junitcore.pc.Balancer
-
Releases a permit, returning it to the balancer.
- releasePermit() - Method in class org.apache.maven.surefire.junitcore.pc.NullBalancer
- releasePermit() - Method in class org.apache.maven.surefire.junitcore.pc.ThreadResourcesBalancer
-
Releases a permit, returning it to the balancer.
- reloadClass(ClassLoader, Object) - Static method in class org.apache.maven.surefire.api.util.ReflectionUtils
- relocate(String) - Static method in class org.apache.maven.plugin.surefire.util.Relocator
- RELOCATION_BASE - Static variable in class org.apache.maven.plugin.surefire.util.Relocator
- Relocator - Class in org.apache.maven.plugin.surefire.util
-
Relocates class names when running with relocated provider
- Relocator() - Constructor for class org.apache.maven.plugin.surefire.util.Relocator
- remoteRepositories - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
The remote plugin repositories declared in the POM.
- remove() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder.CIt
- remove() - Static method in class org.apache.maven.surefire.api.report.ConsoleOutputReceiverForCurrentThread
- remove() - Method in class org.apache.maven.surefire.api.util.CloseableIterator
- remove() - Method in class org.apache.maven.surefire.api.util.TestsToRun.ClassesIterator
- remove() - Method in class org.apache.maven.surefire.booter.CommandReader.ClassesIterator
- remove() - Method in class org.apache.maven.surefire.booter.LazyTestsToRun.BlockingIterator
- remove(Object) - Method in class org.apache.maven.plugin.surefire.SurefireProperties
- removeExclamationMark(String) - Static method in class org.apache.maven.surefire.api.testset.TestListResolver
- removeListener(RunListener) - Method in class org.apache.maven.surefire.common.junit4.Notifier
- removeListeners() - Method in class org.apache.maven.surefire.common.junit4.Notifier
- removeNullRunners(Collection<Runner>) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- removeStream(TestLessInputStream) - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder
- removeUnusedDescriptions(Collection<Description>) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerUtil
- replaceForkThreadsInPath(File, int) - Static method in class org.apache.maven.plugin.surefire.SurefireHelper
- replaceThreadNumberPlaceholders(String, int) - Static method in class org.apache.maven.plugin.surefire.SurefireHelper
- replay(TestReportListener<TestOutputReportEntry>) - Method in class org.apache.maven.surefire.junitcore.TestMethod
-
Deprecated.
- replay(TestReportListener<TestOutputReportEntry>) - Method in class org.apache.maven.surefire.junitcore.TestSet
-
Deprecated.
- reportConfiguration - Variable in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
- reportEntries - Variable in class org.apache.maven.plugin.surefire.report.TestSetStats
- reportEntry - Variable in class org.apache.maven.surefire.api.event.AbstractTestControlEvent
- reportEntry(RunMode, Long, String, String, String, String, String, StackTraceWriter, Integer, String, Map<String, String>) - Static method in class org.apache.maven.surefire.api.report.CategorizedReportEntry
- ReportEntry - Interface in org.apache.maven.surefire.api.report
-
Describes a single entry for a test report
- reportEntryName - Variable in class org.apache.maven.plugin.surefire.report.ConsoleOutputFileReporter
- reportEntryType - Variable in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- ReportEntryType - Enum Class in org.apache.maven.plugin.surefire.report
-
Type of an entry in the report
- ReportEntryType(String, String, String) - Constructor for enum class org.apache.maven.plugin.surefire.report.ReportEntryType
- reporter - Variable in class org.apache.maven.surefire.common.junit4.JUnit4RunListener
- reporter - Variable in class org.apache.maven.surefire.common.junit4.Notifier
- reporter - Variable in class org.apache.maven.surefire.junit.JUnit3Reporter
- reporter - Variable in class org.apache.maven.surefire.junit.JUnitTestSetExecutor
- reporter - Variable in class org.apache.maven.surefire.junit.PojoTestSetExecutor
- reporter - Variable in class org.apache.maven.surefire.junit.TestListenerInvocationHandler
- reporter - Variable in class org.apache.maven.surefire.testng.TestNGReporter
- reporterConfiguration - Variable in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- reporterConfiguration - Variable in class org.apache.maven.surefire.booter.ProviderConfiguration
- reporterConfiguration - Variable in class org.apache.maven.surefire.booter.SurefireReflector
- reporterConfiguration - Variable in class org.apache.maven.surefire.testng.TestNGProvider
- ReporterConfiguration - Class in org.apache.maven.surefire.api.report
-
Bits and pieces of reporting configuration that seem to be necessary on the provider side.
- ReporterConfiguration(File, boolean) - Constructor for class org.apache.maven.surefire.api.report.ReporterConfiguration
- ReporterException - Exception in org.apache.maven.surefire.api.report
-
Exception occurring during report generation.
- ReporterException(String, Exception) - Constructor for exception org.apache.maven.surefire.api.report.ReporterException
- reporterFactory - Variable in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- reporterFactory - Variable in class org.apache.maven.surefire.booter.SurefireReflector
- ReporterFactory - Interface in org.apache.maven.surefire.api.report
-
Used by the providers to request (per-thread) run listeners.
- reporterManagerFactory - Variable in class org.apache.maven.surefire.booter.ProviderFactory
- reporterManagerThreadLocal - Variable in class org.apache.maven.surefire.junitcore.ConcurrentRunListener
-
Deprecated.
- ReporterUtils - Class in org.apache.maven.plugin.surefire.report
-
Utility for reporter classes.
- ReporterUtils() - Constructor for class org.apache.maven.plugin.surefire.report.ReporterUtils
- reportEventListeners - Variable in class org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessEventNotifier
- reportExecution(SurefireReportParameters, RunResult, PluginConsoleLogger, Exception) - Static method in class org.apache.maven.plugin.surefire.SurefireHelper
- reportFormat - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
Selects the formatting for the test report to be generated.
- reportFormat - Variable in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- reportFormat - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
Selects the formatting for the test report to be generated.
- reportImmediately - Variable in class org.apache.maven.surefire.junitcore.ConcurrentRunListener
-
Deprecated.
- reportMerger - Variable in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- reportNameSuffix - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Add custom text into report filename: TEST-testClassName-reportNameSuffix.xml, testClassName-reportNameSuffix.txt and testClassName-reportNameSuffix-output.txt.
- reportNameSuffix - Variable in class org.apache.maven.plugin.surefire.report.ConsoleOutputFileReporter
- reportNameSuffix - Variable in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- reportNameSuffix - Variable in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- reportNameSuffix - Variable in class org.apache.maven.surefire.extensions.StatelessReportMojoConfiguration
- reportNameSuffix - Variable in class org.apache.maven.surefire.extensions.StatelessTestsetInfoFileReportEventListener
- reportsDirectory - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
Base directory where all reports are written to.
- reportsDirectory - Variable in class org.apache.maven.plugin.failsafe.VerifyMojo
-
Base directory where all reports are written to.
- reportsDirectory - Variable in class org.apache.maven.plugin.surefire.report.ConsoleOutputFileReporter
- reportsDirectory - Variable in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- reportsDirectory - Variable in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- reportsDirectory - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
Base directory where all reports are written to.
- reportsDirectory - Variable in class org.apache.maven.surefire.api.report.ReporterConfiguration
- reportsDirectory - Variable in class org.apache.maven.surefire.extensions.StatelessReportMojoConfiguration
- reportsDirectory - Variable in class org.apache.maven.surefire.extensions.StatelessTestsetInfoFileReportEventListener
- reportsDirectory - Variable in class org.apache.maven.surefire.testng.TestNGDirectoryTestSuite
- reportsDirectory - Variable in class org.apache.maven.surefire.testng.TestNGXmlTestSuite
- REPORTSDIRECTORY - Static variable in class org.apache.maven.surefire.booter.BooterConstants
- ReportsMerger - Interface in org.apache.maven.plugin.surefire.report
-
This interface is used to merge reports in
ForkStarter
. - repositorySystem - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- repositorySystem - Variable in class org.apache.maven.plugin.surefire.SurefireDependencyResolver
- RequestedTest - Class in org.apache.maven.surefire.common.junit48
- RequestedTest(ResolvedTest, boolean) - Constructor for class org.apache.maven.surefire.common.junit48.RequestedTest
- REQUESTEDTEST - Static variable in class org.apache.maven.surefire.booter.BooterConstants
- requestedTests - Variable in class org.apache.maven.surefire.api.testset.TestRequest
- requestNextTest() - Method in class org.apache.maven.surefire.booter.CommandReader.ClassesIterator
- requiresRunHistory - Variable in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- requiresRunHistory() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- RERUN_FAILING_TESTS_COUNT - Static variable in class org.apache.maven.surefire.booter.BooterConstants
- RERUN_TEST_AFTER_FAILURE - Enum constant in enum class org.apache.maven.surefire.api.report.RunMode
- rerunFailingTestsCount - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
(JUnit 4+ providers and JUnit 5+ providers since 3.0.0-M4) The number of times each failing test will be rerun.
- rerunFailingTestsCount - Variable in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- rerunFailingTestsCount - Variable in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- rerunFailingTestsCount - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
(JUnit 4+ providers and JUnit 5+ providers since 3.0.0-M4) The number of times each failing test will be rerun.
- rerunFailingTestsCount - Variable in class org.apache.maven.surefire.api.testset.TestRequest
- rerunFailingTestsCount - Variable in class org.apache.maven.surefire.extensions.StatelessReportMojoConfiguration
- rerunFailingTestsCount - Variable in class org.apache.maven.surefire.junit4.JUnit4Provider
- rerunFailingTestsCount - Variable in class org.apache.maven.surefire.junitcore.JUnitCoreProvider
- rerunXmlTag - Variable in enum class org.apache.maven.plugin.surefire.report.ReportEntryType
- reset() - Method in class org.apache.maven.plugin.surefire.report.ConsoleReporter
- reset() - Method in class org.apache.maven.plugin.surefire.report.NullConsoleReporter
- reset() - Method in class org.apache.maven.plugin.surefire.report.TestSetStats
- reset() - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.Memento
- reset() - Method in class org.apache.maven.surefire.common.junit4.JUnitTestFailureListener
- reset() - Method in class org.apache.maven.surefire.extensions.StatelessTestsetInfoConsoleReportEventListener
- reset() - Method in class org.apache.maven.surefire.junitplatform.RunListenerAdapter
- resolutionErrorHandler - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- resolutionErrorHandler - Variable in class org.apache.maven.plugin.surefire.SurefireDependencyResolver
- resolve(String, String, String, String, String) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnitPlatformProviderInfo
- resolve(ConfigurableProviderInfo, ProviderInfo...) - Method in class org.apache.maven.surefire.providerapi.ProviderDetector
- resolveArtifact(Artifact, List<ArtifactRepository>, ArtifactFilter) - Method in class org.apache.maven.plugin.surefire.SurefireDependencyResolver
- resolveClasspath(Commandline, String, StartupConfiguration, File) - Method in class org.apache.maven.plugin.surefire.booterclient.ClasspathForkConfiguration
- resolveClasspath(Commandline, String, StartupConfiguration, File) - Method in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- resolveClasspath(Commandline, String, StartupConfiguration, File) - Method in class org.apache.maven.plugin.surefire.booterclient.JarManifestForkConfiguration
- resolveClasspath(Commandline, String, StartupConfiguration, File) - Method in class org.apache.maven.plugin.surefire.booterclient.ModularClasspathForkConfiguration
- resolveConcurrency(JUnitCoreParameters, RunnerCounter) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerUtil
- ResolvedTest - Class in org.apache.maven.surefire.api.testset
-
Deprecated.will be renamed to ResolvedTestPattern
- ResolvedTest(String, String, boolean) - Constructor for class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.'*' means zero or more characters
'?' means one and only one character The pattern %regex[] prefix and suffix does not appear. - ResolvedTest(ResolvedTest.Type, String, boolean) - Constructor for class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.The regex
pattern
is always unwrapped. - ResolvedTest.ClassMatcher - Class in org.apache.maven.surefire.api.testset
-
Deprecated.
- ResolvedTest.MethodMatcher - Class in org.apache.maven.surefire.api.testset
-
Deprecated.
- ResolvedTest.Type - Enum Class in org.apache.maven.surefire.api.testset
-
Deprecated.Type of patterns in ResolvedTest constructor.
- resolveLevel(boolean, boolean, boolean, boolean, boolean) - Static method in enum class org.apache.maven.plugin.surefire.log.api.Level
- resolvePathResult - Variable in class org.apache.maven.plugin.surefire.ResolvePathResultWrapper
- ResolvePathResultWrapper - Class in org.apache.maven.plugin.surefire
-
Wraps
ResolvePathResult
and place marker. - ResolvePathResultWrapper(ResolvePathResult, boolean) - Constructor for class org.apache.maven.plugin.surefire.ResolvePathResultWrapper
- resolvePluginArtifact(Artifact) - Method in class org.apache.maven.plugin.surefire.SurefireDependencyResolver
- resolvePluginArtifact(Artifact, ArtifactFilter) - Method in class org.apache.maven.plugin.surefire.SurefireDependencyResolver
- resolvePluginDependencies(Plugin, Map<String, Artifact>) - Method in class org.apache.maven.plugin.surefire.SurefireDependencyResolver
- resolveProjectArtifact(Artifact) - Method in class org.apache.maven.plugin.surefire.SurefireDependencyResolver
- resolveProjectArtifact(Artifact, ArtifactFilter) - Method in class org.apache.maven.plugin.surefire.SurefireDependencyResolver
- resolveReportsDirectory(Integer) - Method in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- resolveTestRequest(String, IncludedExcludedPatterns, Collection<ResolvedTest>, Collection<ResolvedTest>) - Static method in class org.apache.maven.surefire.api.testset.TestListResolver
-
Requires trimmed
request
been not equal to "!". - resultType - Variable in class org.apache.maven.plugin.surefire.report.TestMethodStats
- retainInProcArtifactsUnique(Set<Artifact>, Artifact...) - Static method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- rethrowAnyTestMechanismFailures(Result) - Static method in class org.apache.maven.surefire.common.junit4.JUnit4RunListener
- returnNumber(int) - Static method in class org.apache.maven.plugin.surefire.booterclient.ForkNumberBucket
- returnNumberInternal(int) - Method in class org.apache.maven.plugin.surefire.booterclient.ForkNumberBucket
- reuseForks - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Indicates if forked VMs can be reused.
- reuseForks - Variable in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- REVERSE_ALPHABETICAL - Static variable in class org.apache.maven.surefire.api.util.RunOrder
- roleName - Variable in class org.apache.maven.surefire.booter.IsolatedClassLoader
- rootIsInclass() - Method in class org.apache.maven.surefire.report.SmartStackTraceParser
- run() - Method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter.CloseableCloser
- run() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.Pumper
-
Calls
ForkClient.handleEvent(Event)
which may throw anyRuntimeException
.
Even ifForkClient
is not fault-tolerant, this method MUST be fault-tolerant and thus the try-catch block must be inside of the loop which prevents from loosing events fromEventHandler
. - run() - Method in class org.apache.maven.plugin.surefire.extensions.EventConsumerThread
- run() - Method in class org.apache.maven.plugin.surefire.extensions.StreamFeeder
- run() - Method in class org.apache.maven.surefire.booter.CommandReader.CommandRunnable
- run() - Method in class org.apache.maven.surefire.extensions.util.CommandlineExecutor.ProcessHook
- run() - Method in class org.apache.maven.surefire.extensions.util.LineConsumerThread
- run(Iterable<Class<?>>, String, Map<String, String>, TestNGReporter, File, TestListResolver, List<CommandLineOption>, int) - Static method in class org.apache.maven.surefire.testng.TestNGExecutor
- run(List<String>, String, Map<String, String>, TestNGReporter, File, int) - Static method in class org.apache.maven.surefire.testng.TestNGExecutor
- run(SurefireProperties) - Method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- run(SurefireProperties, Map<String, String>) - Method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- run(SurefireProperties, DefaultScanResult) - Method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- run(ForkedBooter, String[]) - Static method in class org.apache.maven.surefire.booter.ForkedBooter
-
created for testing purposes.
- run(Runner) - Method in class org.apache.maven.surefire.junitcore.JUnitCore
- RUN - Static variable in class org.apache.maven.plugin.surefire.report.TestSetStats
- RUN_CLASS - Enum constant in enum class org.apache.maven.surefire.api.booter.MasterProcessCommand
- RUN_METHOD - Static variable in class org.apache.maven.surefire.common.junit3.JUnit3Reflector
- RUN_MODE - Enum constant in enum class org.apache.maven.surefire.api.stream.SegmentType
- RUN_MODES - Static variable in enum class org.apache.maven.surefire.api.report.RunMode
- RUN_MODES - Static variable in class org.apache.maven.surefire.stream.EventDecoder
- RUN_ORDER - Static variable in class org.apache.maven.surefire.booter.BooterConstants
- RUN_ORDER_RANDOM_SEED - Static variable in class org.apache.maven.surefire.booter.BooterConstants
- RUN_STATISTICS_FILE - Static variable in class org.apache.maven.surefire.booter.BooterConstants
- runCompleted() - Method in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
- RunCountComparator() - Constructor for class org.apache.maven.surefire.api.runorder.RunEntryStatisticsMap.RunCountComparator
- runEntryStatistics - Variable in class org.apache.maven.surefire.api.runorder.RunEntryStatisticsMap
- RunEntryStatistics - Class in org.apache.maven.surefire.api.runorder
- RunEntryStatistics(int, int, String, String) - Constructor for class org.apache.maven.surefire.api.runorder.RunEntryStatistics
- RunEntryStatistics(int, int, ClassMethod) - Constructor for class org.apache.maven.surefire.api.runorder.RunEntryStatistics
- RunEntryStatisticsMap - Class in org.apache.maven.surefire.api.runorder
- RunEntryStatisticsMap() - Constructor for class org.apache.maven.surefire.api.runorder.RunEntryStatisticsMap
- RunEntryStatisticsMap(Map<ClassMethod, RunEntryStatistics>) - Constructor for class org.apache.maven.surefire.api.runorder.RunEntryStatisticsMap
- RunEntryStatisticsMap.LeastFailureComparator - Class in org.apache.maven.surefire.api.runorder
- RunEntryStatisticsMap.PrioritizedTestComparator - Class in org.apache.maven.surefire.api.runorder
- RunEntryStatisticsMap.RunCountComparator - Class in org.apache.maven.surefire.api.runorder
- RunEntryStatisticsMap.TestRuntimeComparator - Class in org.apache.maven.surefire.api.runorder
- runIfZeroCountDown(Runnable, AtomicInteger) - Static method in class org.apache.maven.surefire.api.util.internal.ConcurrencyUtils
-
Decreases
counter
to zero, or does not change the counter if negative. - runListener - Variable in class org.apache.maven.surefire.junitplatform.RunListenerAdapter
- RunListener - Interface in org.apache.maven.surefire.api.report
-
Used by providers to report results.
- RunListenerAdapter - Class in org.apache.maven.surefire.junitplatform
- RunListenerAdapter(TestReportListener<TestOutputReportEntry>) - Constructor for class org.apache.maven.surefire.junitplatform.RunListenerAdapter
- runmode - Variable in enum class org.apache.maven.surefire.api.report.RunMode
- runMode - Variable in class org.apache.maven.surefire.api.event.AbstractStandardStreamEvent
- runMode - Variable in class org.apache.maven.surefire.api.event.SystemPropertyEvent
- runMode - Variable in class org.apache.maven.surefire.api.report.SimpleReportEntry
- runMode - Variable in class org.apache.maven.surefire.api.report.TestOutputReportEntry
- runMode - Variable in class org.apache.maven.surefire.common.junit4.JUnit4RunListener
- runMode - Variable in class org.apache.maven.surefire.junit.JUnit3Reporter
- runMode - Variable in class org.apache.maven.surefire.junitcore.TestSet
-
Deprecated.
- runMode - Variable in class org.apache.maven.surefire.junitplatform.RunListenerAdapter
- runMode - Variable in class org.apache.maven.surefire.testng.TestNGReporter
- RunMode - Enum Class in org.apache.maven.surefire.api.report
-
Determines the purpose the provider started the tests.
- RunMode(String) - Constructor for enum class org.apache.maven.surefire.api.report.RunMode
- runmodeBinary - Variable in enum class org.apache.maven.surefire.api.report.RunMode
- RunModeSetter - Interface in org.apache.maven.surefire.report
-
Sets the run mode in a listener, reflects the run mode of testset execution.
- RunnerCounter - Class in org.apache.maven.surefire.junitcore.pc
-
Counts number of JUnit suites, classes and methods.
- RunnerCounter(long, long, long) - Constructor for class org.apache.maven.surefire.junitcore.pc.RunnerCounter
- runningInTests - Variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- runningTestIdentifiersByUniqueId - Variable in class org.apache.maven.surefire.junitplatform.RunListenerAdapter
- runOrder - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
Defines the order the tests will be run in.
- runOrder - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
Defines the order the tests will be run in.
- runOrder - Variable in class org.apache.maven.surefire.api.testset.DirectoryScannerParameters
- runOrder - Variable in class org.apache.maven.surefire.api.testset.RunOrderParameters
- runOrder - Variable in class org.apache.maven.surefire.api.util.DefaultRunOrderCalculator
- RunOrder - Class in org.apache.maven.surefire.api.util
-
A RunOrder specifies the order in which the tests will be run.
- RunOrder(String) - Constructor for class org.apache.maven.surefire.api.util.RunOrder
- runOrderCalculator - Variable in class org.apache.maven.surefire.junit.JUnit3Provider
- runOrderCalculator - Variable in class org.apache.maven.surefire.junit4.JUnit4Provider
- runOrderCalculator - Variable in class org.apache.maven.surefire.junitcore.JUnitCoreProvider
- runOrderCalculator - Variable in class org.apache.maven.surefire.testng.TestNGProvider
- RunOrderCalculator - Interface in org.apache.maven.surefire.api.util
- runOrderParameters - Variable in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- runOrderParameters - Variable in class org.apache.maven.surefire.api.util.DefaultRunOrderCalculator
- runOrderParameters - Variable in class org.apache.maven.surefire.booter.ProviderConfiguration
- runOrderParameters - Variable in class org.apache.maven.surefire.booter.SurefireReflector
- RunOrderParameters - Class in org.apache.maven.surefire.api.testset
- RunOrderParameters(String, File) - Constructor for class org.apache.maven.surefire.api.testset.RunOrderParameters
- RunOrderParameters(String, File, Long) - Constructor for class org.apache.maven.surefire.api.testset.RunOrderParameters
- RunOrderParameters(RunOrder[], File) - Constructor for class org.apache.maven.surefire.api.testset.RunOrderParameters
- RunOrderParameters(RunOrder[], File, Long) - Constructor for class org.apache.maven.surefire.api.testset.RunOrderParameters
- runOrderRandomSeed - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
Sets the random seed that will be used to order the tests if
failsafe.runOrder
is set torandom
. - runOrderRandomSeed - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
Sets the random seed that will be used to order the tests if
surefire.runOrder
is set torandom
. - runOrderRandomSeed - Variable in class org.apache.maven.surefire.api.testset.RunOrderParameters
- runResult - Variable in class org.apache.maven.surefire.booter.SurefireReflector
- RunResult - Class in org.apache.maven.surefire.api.suite
-
Represents a test-run-result; this may be from a single test run or an aggregated result.
- RunResult(int, int, int, int) - Constructor for class org.apache.maven.surefire.api.suite.RunResult
- RunResult(int, int, int, int, int) - Constructor for class org.apache.maven.surefire.api.suite.RunResult
- RunResult(int, int, int, int, int, String, boolean) - Constructor for class org.apache.maven.surefire.api.suite.RunResult
- RunResult(int, int, int, int, String, boolean) - Constructor for class org.apache.maven.surefire.api.suite.RunResult
- runStarting() - Method in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
- runStarting() - Method in interface org.apache.maven.plugin.surefire.report.ReportsMerger
- RunStatistics - Class in org.apache.maven.surefire.report
- RunStatistics() - Constructor for class org.apache.maven.surefire.report.RunStatistics
- runStatisticsFile - Variable in class org.apache.maven.surefire.api.testset.RunOrderParameters
- runSuitesForkOnceMultiple(SurefireProperties, int) - Method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- runSuitesForkPerTestSet(SurefireProperties, int) - Method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- runSuitesInProcess() - Method in class org.apache.maven.surefire.booter.ForkedBooter
- runSuitesInProcess(DefaultScanResult) - Method in class org.apache.maven.plugin.surefire.InPluginVMSurefireStarter
- runTime - Variable in class org.apache.maven.surefire.api.runorder.RunEntryStatistics
- runTime - Variable in class org.apache.maven.surefire.api.runorder.ThreadedExecutionScheduler
- RuntimeArtifactFilter() - Constructor for class org.apache.maven.plugin.surefire.SurefireDependencyResolver.RuntimeArtifactFilter
- RuntimeArtifactFilter(Artifact) - Constructor for class org.apache.maven.plugin.surefire.SurefireDependencyResolver.RuntimeArtifactFilter
- runWith - Variable in class org.apache.maven.surefire.common.junit4.JUnit4TestChecker
- rwLock - Variable in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder
S
- safeGetMessage(Throwable) - Method in class org.apache.maven.surefire.junitplatform.RunListenerAdapter
- safeGetMessage(StackTraceWriter) - Static method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- SafeThrowable - Class in org.apache.maven.surefire.api.report
-
Guards against misbehaving throwables
- SafeThrowable(String) - Constructor for class org.apache.maven.surefire.api.report.SafeThrowable
- SafeThrowable(Throwable) - Constructor for class org.apache.maven.surefire.api.report.SafeThrowable
- saidGoodBye - Variable in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
-
Written by one Thread and read by another: Main Thread and ForkStarter's Thread.
- sanityCheck() - Method in class org.apache.maven.surefire.api.testset.ResolvedTest.MethodMatcher
-
Deprecated.
- scan() - Method in class org.apache.maven.plugin.surefire.util.DependencyScanner
- scan() - Method in class org.apache.maven.plugin.surefire.util.DirectoryScanner
- scan(Collection<String>, TestFilter<String, String>, File, String...) - Method in class org.apache.maven.plugin.surefire.util.FileScanner
- SCAN_RESULT_NUMBER - Static variable in class org.apache.maven.surefire.api.util.DefaultScanResult
- scanArtifact(File, TestFilter<String, String>, Set<String>) - Static method in class org.apache.maven.plugin.surefire.util.DependencyScanner
- scanClasspath() - Method in class org.apache.maven.surefire.junitplatform.JUnitPlatformProvider
- scanClassPath() - Method in class org.apache.maven.surefire.junit.JUnit3Provider
- scanClassPath() - Method in class org.apache.maven.surefire.junit4.JUnit4Provider
- scanClassPath() - Method in class org.apache.maven.surefire.junitcore.JUnitCoreProvider
- scanClassPath() - Method in class org.apache.maven.surefire.testng.TestNGProvider
- scanDependencies() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- scanDirectories() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- scanForTestClasses() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- scannerFilter - Variable in class org.apache.maven.surefire.junitcore.JUnitCoreProvider
- ScannerFilter - Interface in org.apache.maven.surefire.api.util
- ScannerUtil - Class in org.apache.maven.plugin.surefire.util
- ScannerUtil() - Constructor for class org.apache.maven.plugin.surefire.util.ScannerUtil
- scanResult - Variable in class org.apache.maven.surefire.junit.JUnit3Provider
- scanResult - Variable in class org.apache.maven.surefire.junit4.JUnit4Provider
- scanResult - Variable in class org.apache.maven.surefire.junitcore.JUnitCoreProvider
- scanResult - Variable in class org.apache.maven.surefire.testng.TestNGProvider
- ScanResult - Interface in org.apache.maven.surefire.api.util
- scanTo(Collection<String>, TestFilter<String, String>) - Method in class org.apache.maven.plugin.surefire.util.FileScanner
- schedule(Runnable) - Method in class org.apache.maven.surefire.junitcore.AsynchronousRunner
-
Deprecated.
- schedule(Runnable) - Method in class org.apache.maven.surefire.junitcore.pc.AbstractThreadPoolStrategy
- schedule(Runnable) - Method in class org.apache.maven.surefire.junitcore.pc.InvokerStrategy
- schedule(Runnable) - Method in class org.apache.maven.surefire.junitcore.pc.Scheduler
- schedule(Runnable) - Method in class org.apache.maven.surefire.junitcore.pc.SchedulingStrategy
-
Schedules tasks if
SchedulingStrategy.canSchedule()
. - schedule(Runnable) - Method in class org.apache.maven.surefire.junitcore.SynchronousRunner
-
Deprecated.
- scheduleForcedShutdown() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputer
- schedulePeriodicFlusher(int, WritableBufferedByteChannel) - Method in class org.apache.maven.surefire.booter.spi.AbstractMasterProcessChannelProcessorFactory
- Scheduler - Class in org.apache.maven.surefire.junitcore.pc
-
Schedules tests, controls thread resources, awaiting tests and other schedulers finished, and a master scheduler can shutdown slaves.
- Scheduler(ConsoleLogger, Description, Scheduler, SchedulingStrategy) - Constructor for class org.apache.maven.surefire.junitcore.pc.Scheduler
-
Should be used with individual pools on suites, classes and methods, see
ParallelComputerBuilder.useSeparatePools()
. - Scheduler(ConsoleLogger, Description, Scheduler, SchedulingStrategy, int) - Constructor for class org.apache.maven.surefire.junitcore.pc.Scheduler
- Scheduler(ConsoleLogger, Description, Scheduler, SchedulingStrategy, Balancer) - Constructor for class org.apache.maven.surefire.junitcore.pc.Scheduler
-
Can be used by e.g.
- Scheduler(ConsoleLogger, Description, SchedulingStrategy) - Constructor for class org.apache.maven.surefire.junitcore.pc.Scheduler
-
Use e.g.
- Scheduler(ConsoleLogger, Description, SchedulingStrategy, int) - Constructor for class org.apache.maven.surefire.junitcore.pc.Scheduler
-
Should be used if schedulers in parallel children and parent use one instance of bounded thread pool.
- Scheduler(ConsoleLogger, Description, SchedulingStrategy, Balancer) - Constructor for class org.apache.maven.surefire.junitcore.pc.Scheduler
-
New instances should be used by schedulers with limited concurrency by
balancer
against other groups of schedulers. - Scheduler.Controller - Class in org.apache.maven.surefire.junitcore.pc
-
If this is a master scheduler, the slaves can stop scheduling by the master through the controller.
- Scheduler.ShutdownHandler - Class in org.apache.maven.surefire.junitcore.pc
-
There is a way to shutdown the hierarchy of schedulers.
- scheduleShutdown() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputer
- SchedulingStrategies - Class in org.apache.maven.surefire.junitcore.pc
-
The factory of
SchedulingStrategy
. - SchedulingStrategies() - Constructor for class org.apache.maven.surefire.junitcore.pc.SchedulingStrategies
- SchedulingStrategy - Class in org.apache.maven.surefire.junitcore.pc
-
Specifies the strategy of scheduling whether sequential, or parallel.
- SchedulingStrategy(ConsoleLogger) - Constructor for class org.apache.maven.surefire.junitcore.pc.SchedulingStrategy
- SCOPES - Static variable in class org.apache.maven.plugin.surefire.SurefireDependencyResolver.RuntimeArtifactFilter
- secondsToNanos(double) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputer
- Segment(byte[], int, int) - Constructor for class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.Segment
- segmentsToCmds() - Static method in enum class org.apache.maven.surefire.api.booter.MasterProcessCommand
- segmentsToEvents() - Static method in class org.apache.maven.surefire.stream.EventDecoder
- segmentsToRunModes() - Static method in enum class org.apache.maven.surefire.api.report.RunMode
- segmentsToRunModes() - Static method in class org.apache.maven.surefire.stream.EventDecoder
- SegmentType - Enum Class in org.apache.maven.surefire.api.stream
- SegmentType() - Constructor for enum class org.apache.maven.surefire.api.stream.SegmentType
- sendByeAck() - Method in class org.apache.maven.surefire.stream.CommandEncoder
- sendExitError(StackTraceWriter, boolean) - Method in interface org.apache.maven.surefire.api.booter.MasterProcessChannelEncoder
-
ForkedBooter tear down has failed while waiting for BYE_ACK command.
- sendExitError(StackTraceWriter, boolean) - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- sendNoop() - Method in class org.apache.maven.surefire.stream.CommandEncoder
- sendRunClass(String) - Method in class org.apache.maven.surefire.stream.CommandEncoder
- sendShutdown(String) - Method in class org.apache.maven.surefire.stream.CommandEncoder
- sendSkipSinceNextTest() - Method in class org.apache.maven.surefire.stream.CommandEncoder
- sendTestSetFinished() - Method in class org.apache.maven.surefire.stream.CommandEncoder
- serialize(File) - Method in class org.apache.maven.surefire.api.runorder.RunEntryStatisticsMap
- serialize(KeyValueSource, ProviderConfiguration, StartupConfiguration, Object, boolean, Long, int, String) - Method in class org.apache.maven.plugin.surefire.booterclient.BooterSerializer
-
Does not modify sourceProperties
- serializeTestClass(OutputStream, OutputStreamWriter, XMLWriter, List<WrappedReportEntry>) - Method in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- serializeTestClassWithoutRerun(OutputStream, OutputStreamWriter, XMLWriter, List<WrappedReportEntry>) - Method in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- serializeTestClassWithRerun(OutputStream, OutputStreamWriter, XMLWriter, List<WrappedReportEntry>) - Method in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- serialVersionUID - Static variable in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.QueueSynchronizer.SyncT1
- serialVersionUID - Static variable in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.QueueSynchronizer.SyncT2
- server - Variable in class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel
- serviceLoader - Variable in class org.apache.maven.surefire.providerapi.ProviderDetector
- ServiceLoader - Class in org.apache.maven.surefire.providerapi
-
SPI loader for Surefire/Failsafe should use
current ClassLoader
. - ServiceLoader() - Constructor for class org.apache.maven.surefire.providerapi.ServiceLoader
- session - Variable in class org.apache.maven.plugin.failsafe.VerifyMojo
-
The current build session instance.
- session - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
The current build session instance.
- session - Variable in class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel
- sessionId - Variable in class org.apache.maven.plugin.surefire.booterclient.ForkStarter.ForkedNodeArg
- sessionId - Variable in class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel
- set(int, int, int, int, int) - Method in class org.apache.maven.surefire.report.RunStatistics
- set(TestOutputReceiver) - Static method in class org.apache.maven.surefire.api.report.ConsoleOutputReceiverForCurrentThread
- setAcquireNextTestListener(ForkedProcessEventListener) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessEventNotifier
- setAdditionalClasspathElements(String[]) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setAllScheduled(TestReportListener) - Method in class org.apache.maven.surefire.junitcore.TestSet
-
Deprecated.
- setArgLine(String) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setAsSystemProperties() - Method in class org.apache.maven.surefire.booter.PropertiesWrapper
- setBasedir(File) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setBasedir(File) - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
- setBasedir(File) - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- setBasedir(File) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setBasedir(File) - Method in interface org.apache.maven.plugin.surefire.SurefireReportParameters
- setByeListener(ForkedProcessEventListener) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessEventNotifier
- setCachedClasspath(String, Set<Artifact>) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.ClasspathCache
- setCachedClasspath(String, Set<Artifact>) - Static method in class org.apache.maven.plugin.surefire.ClasspathCache
-
Deprecated.
- setCachedClasspath(String, Classpath) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.ClasspathCache
- setCachedClasspath(String, Classpath) - Static method in class org.apache.maven.plugin.surefire.ClasspathCache
-
Deprecated.
- setCharset(Charset) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.Memento
- setChildDelegation(boolean) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setClassLoaders(ClassLoader) - Method in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- setClasspath(String, Classpath) - Method in class org.apache.maven.plugin.surefire.SurefireProperties
- setClasspath(String, Classpath) - Method in class org.apache.maven.surefire.booter.PropertiesWrapper
- setClasspathDependencyExcludes(String[]) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setClasspathDependencyScopeExclude(String) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setCommandReader(CommandChainReader) - Method in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- setConsoleDebugListener(ForkedProcessStringEventListener) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessEventNotifier
- setConsoleErrorListener(ForkedProcessStackTraceEventListener) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessEventNotifier
- setConsoleInfoListener(ForkedProcessStringEventListener) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessEventNotifier
- setConsoleWarningListener(ForkedProcessStringEventListener) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessEventNotifier
- setController(Scheduler.Controller) - Method in class org.apache.maven.surefire.junitcore.pc.Scheduler
- setCurrentStartTime() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
- setDebugForkedProcess(String) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setDebugForkedProcess(String) - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- setDebugForkedProcess(String) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setDefaultAvailableProcessors() - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerUtil
- setDefaultClassesDirectory(File) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setDefaultShutdownHandler(Scheduler.ShutdownHandler) - Method in class org.apache.maven.surefire.junitcore.pc.AbstractThreadPoolStrategy
- setDefaultShutdownHandler(Scheduler.ShutdownHandler) - Method in class org.apache.maven.surefire.junitcore.pc.SchedulingStrategy
- setDependenciesToScan(String[]) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setDescriptionsBeforeShutdown(Future<ShutdownResult>) - Method in class org.apache.maven.surefire.junitcore.pc.ShutdownStatus
- setDirectoryScannerParameters(Object, DirectoryScannerParameters) - Method in class org.apache.maven.surefire.booter.SurefireReflector
- setDirectoryScannerParameters(DirectoryScannerParameters) - Method in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- setDisable(boolean) - Method in class org.apache.maven.surefire.extensions.ConsoleOutputReporter
- setDisable(boolean) - Method in class org.apache.maven.surefire.extensions.StatelessReporter
- setDisable(boolean) - Method in class org.apache.maven.surefire.extensions.StatelessTestsetInfoReporter
- setDisableXmlReport(boolean) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setEnableAssertions(boolean) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setEncoding(String) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setEncoding(String) - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- setEncoding(String) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setEncoding(String) - Method in class org.apache.maven.surefire.extensions.ConsoleOutputReporter
- setEndTime() - Method in class org.apache.maven.surefire.junitcore.TestMethod
-
Deprecated.
- setEnvironmentVariables(Map<String, String>) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setExcludedEnvironmentVariables(String[]) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setExcludedEnvironmentVariables(String[]) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setExcludedGroups(String) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setExcludeJUnit5Engines(String[]) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setExcludeJUnit5Engines(String[]) - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- setExcludeJUnit5Engines(String[]) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setExcludes(List<String>) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setExcludes(List<String>) - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- setExcludes(List<String>) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setExitErrorEventListener(ForkedProcessExitErrorListener) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessEventNotifier
- setFailIfNoSpecifiedTests(boolean) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setFailIfNoSpecifiedTests(boolean) - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- setFailIfNoSpecifiedTests(boolean) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setFailIfNoTests(boolean) - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
- setFailIfNoTests(boolean) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setFailIfNoTests(boolean) - Method in interface org.apache.maven.plugin.surefire.SurefireReportParameters
- setFailOnFlakeCount(int) - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
- setFailOnFlakeCount(int) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setFailOnFlakeCount(int) - Method in interface org.apache.maven.plugin.surefire.SurefireReportParameters
- setForkedProcessExitTimeoutInSeconds(int) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setForkedProcessExitTimeoutInSeconds(int) - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- setForkedProcessExitTimeoutInSeconds(int) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setForkedProcessTimeoutInSeconds(int) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setForkedProcessTimeoutInSeconds(int) - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- setForkedProcessTimeoutInSeconds(int) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setForkMode(String) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setGroups(String) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setIfDirScannerAware(Object, DirectoryScannerParameters) - Method in class org.apache.maven.surefire.booter.SurefireReflector
- setIncludeJUnit5Engines(String[]) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setIncludeJUnit5Engines(String[]) - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- setIncludeJUnit5Engines(String[]) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setIncludes(List<String>) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setIncludes(List<String>) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setIncludes(List<String>) - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- setIncludes(List<String>) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setJdkToolchain(Map<String, String>) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setJunitArtifactName(String) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setLeafInfinite(JUnitCoreParameters, Concurrency) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerUtil
- setLocalRepository(ArtifactRepository) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setLocalRepository(ArtifactRepository) - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- setLogger(Logger) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setMainBuildPath(File) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setMainBuildPath(File) - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- setMainBuildPath(File) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setMainCliOptions(Object, List<CommandLineOption>) - Method in class org.apache.maven.surefire.booter.SurefireReflector
- setMainCliOptions(List<CommandLineOption>) - Method in class org.apache.maven.surefire.api.booter.BaseProviderFactory
-
CLI options in plugin (main) JVM process.
- setNullableProperty(String, String) - Method in class org.apache.maven.plugin.surefire.SurefireProperties
- setObjectFactory(String) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setOutErr(ForkedProcessEventType, RunMode, Long, String) - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- setParallel(String) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setParallelOptimized(boolean) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setParallelTestsTimeoutForcedInSeconds(double) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setParallelTestsTimeoutForcedInSeconds(double) - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- setParallelTestsTimeoutForcedInSeconds(double) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setParallelTestsTimeoutInSeconds(double) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setParallelTestsTimeoutInSeconds(double) - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- setParallelTestsTimeoutInSeconds(double) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setPerCoreThreadCount(boolean) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setPluginArtifactMap(Map<String, Artifact>) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setPluginDescriptor(PluginDescriptor) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setPositionByteBuffer(int) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.BufferedStream
- setPrintSummary(boolean) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setPrintSummary(boolean) - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- setPrintSummary(boolean) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setPriority(int) - Method in class org.apache.maven.surefire.api.runorder.Priority
- setProject(MavenProject) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setProjectArtifactMap(Map<String, Artifact>) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setProjectBuildDirectory(File) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setProjectRemoteRepositories(List<ArtifactRepository>) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setProperties(Properties) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setProperty(String, int) - Method in class org.apache.maven.plugin.surefire.SurefireProperties
- setProperty(String, File) - Method in class org.apache.maven.plugin.surefire.SurefireProperties
- setProperty(String, Boolean) - Method in class org.apache.maven.plugin.surefire.SurefireProperties
- setProperty(String, Long) - Method in class org.apache.maven.plugin.surefire.SurefireProperties
- setProperty(String, String) - Method in class org.apache.maven.surefire.booter.PropertiesWrapper
- setProviderProperties(Object, Map<String, String>) - Method in class org.apache.maven.surefire.booter.SurefireReflector
- setProviderProperties(Map<String, String>) - Method in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- setProviderPropertiesAware(Object, Map<String, String>) - Method in class org.apache.maven.surefire.booter.SurefireReflector
- setRedirectTestOutputToFile(boolean) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setRejectedExecutionHandler(RejectedExecutionHandler) - Method in class org.apache.maven.surefire.junitcore.pc.Scheduler.ShutdownHandler
- setRemoteRepositories(List<ArtifactRepository>) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setReporterConfiguration(Object, ReporterConfiguration) - Method in class org.apache.maven.surefire.booter.SurefireReflector
- setReporterConfiguration(ReporterConfiguration) - Method in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- setReporterConfigurationAware(Object, ReporterConfiguration) - Method in class org.apache.maven.surefire.booter.SurefireReflector
- setReporterFactory(Object, Object) - Method in class org.apache.maven.surefire.booter.SurefireReflector
- setReporterFactory(ReporterFactory) - Method in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- setReporterFactoryAware(Object, Object) - Method in class org.apache.maven.surefire.booter.SurefireReflector
- setReportFormat(String) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setReportFormat(String) - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- setReportFormat(String) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setReportNameSuffix(String) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setReportsDirectory(File) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setReportsDirectory(File) - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
- setReportsDirectory(File) - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- setReportsDirectory(File) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setReportsDirectory(File) - Method in interface org.apache.maven.plugin.surefire.SurefireReportParameters
- setRepositorySystem(RepositorySystem) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setResolutionErrorHandler(ResolutionErrorHandler) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setRunMode(RunMode) - Method in class org.apache.maven.surefire.common.junit4.JUnit4RunListener
- setRunMode(RunMode) - Method in class org.apache.maven.surefire.junit.JUnit3Reporter
- setRunMode(RunMode) - Method in class org.apache.maven.surefire.junitplatform.RunListenerAdapter
- setRunMode(RunMode) - Method in interface org.apache.maven.surefire.report.RunModeSetter
- setRunMode(RunMode) - Method in class org.apache.maven.surefire.testng.TestNGReporter
- setRunOrder(String) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setRunOrder(String) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setRunOrder(String) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setRunOrderParameters(Object, RunOrderParameters) - Method in class org.apache.maven.surefire.booter.SurefireReflector
- setRunOrderParameters(RunOrderParameters) - Method in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- setRunOrderRandomSeed(Long) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setRunOrderRandomSeed(Long) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setRunOrderRandomSeed(Long) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setRunOrderRandomSeed(Long) - Method in class org.apache.maven.surefire.api.testset.RunOrderParameters
- setSchedulers(Iterable<? extends ParentRunner>, int, ExecutorService) - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- setSchedulers(ParentRunner, ParentRunner) - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- setSession(MavenSession) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setShutdownState() - Method in class org.apache.maven.plugin.surefire.booterclient.Platform
- setSkip(boolean) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setSkip(boolean) - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
- setSkip(boolean) - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- setSkip(boolean) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setSkip(boolean) - Method in interface org.apache.maven.plugin.surefire.SurefireReportParameters
- setSkipAfterFailureCount(int) - Method in class org.apache.maven.surefire.api.booter.BaseProviderFactory
-
See the plugin configuration parameter "skipAfterFailureCount".
- setSkipAfterFailureCount(Object, int) - Method in class org.apache.maven.surefire.booter.SurefireReflector
- setSkipExec(boolean) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
Deprecated.
- setSkipExec(boolean) - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
-
Deprecated.
- setSkipExec(boolean) - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- setSkipExec(boolean) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setSkipExec(boolean) - Method in interface org.apache.maven.plugin.surefire.SurefireReportParameters
- setSkipITs(boolean) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setSkipITs(boolean) - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
- setSkipOnNextTest() - Method in class org.apache.maven.surefire.testng.utils.FailFastEventsSingleton
- setSkipTests(boolean) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
Deprecated.
- setSkipTests(boolean) - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
- setSkipTests(boolean) - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- setSkipTests(boolean) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setSkipTests(boolean) - Method in interface org.apache.maven.plugin.surefire.SurefireReportParameters
- setStdErrListener(ForkedProcessStandardOutErrEventListener) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessEventNotifier
- setStdOutListener(ForkedProcessStandardOutErrEventListener) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessEventNotifier
- setStopOnNextTestListener(ForkedProcessEventListener) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
- setStopOnNextTestListener(ForkedProcessEventListener) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessEventNotifier
- setSuiteXmlFiles(File[]) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setSuiteXmlFiles(File[]) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setSuiteXmlFiles(File[]) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setSummaryFile(File) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setSystemExitTimeout(Integer) - Method in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- setSystemExitTimeout(Object, Integer) - Method in class org.apache.maven.surefire.booter.SurefireReflector
- setSystemManager(String) - Static method in class org.apache.maven.surefire.junit.JUnit3Provider
- setSystemProperties(File) - Static method in class org.apache.maven.surefire.booter.SystemPropertyManager
- setSystemProperties(Properties) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setSystemPropertiesFile(File) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setSystemPropertiesFile(File) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setSystemPropertiesFile(File) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setSystemPropertiesListener(ForkedProcessPropertyEventListener) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessEventNotifier
- setSystemPropertyVariables(Map<String, String>) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setTempDir(String) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- Setter(String, Class<?>) - Constructor for class org.apache.maven.surefire.testng.conf.AbstractDirectConfigurator.Setter
- setterName - Variable in class org.apache.maven.surefire.testng.conf.AbstractDirectConfigurator.Setter
- setters - Variable in class org.apache.maven.surefire.testng.conf.AbstractDirectConfigurator
- setTest(String) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setTest(String) - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- setTest(String) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setTestArtifactInfo(Object, TestArtifactInfo) - Method in class org.apache.maven.surefire.booter.SurefireReflector
- setTestArtifactInfo(TestArtifactInfo) - Method in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- setTestArtifactInfoAware(Object, TestArtifactInfo) - Method in class org.apache.maven.surefire.booter.SurefireReflector
- setTestAssumptionFailureListener(ForkedProcessReportEventListener<?>) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessEventNotifier
- setTestClassesDirectory(File) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setTestClassesDirectory(File) - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
- setTestClassesDirectory(File) - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- setTestClassesDirectory(File) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setTestClassesDirectory(File) - Method in interface org.apache.maven.plugin.surefire.SurefireReportParameters
- setTestClassLoader(Object, ClassLoader) - Method in class org.apache.maven.surefire.booter.SurefireReflector
- setTestClassLoaderAware(Object, ClassLoader) - Method in class org.apache.maven.surefire.booter.SurefireReflector
- setTestErrorListener(ForkedProcessReportEventListener<?>) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessEventNotifier
- setTestFailedListener(ForkedProcessReportEventListener<?>) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessEventNotifier
- setTestFailureIgnore(boolean) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setTestFailureIgnore(boolean) - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
- setTestFailureIgnore(boolean) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setTestFailureIgnore(boolean) - Method in interface org.apache.maven.plugin.surefire.SurefireReportParameters
- setTestListResolver(TestListResolver) - Static method in class org.apache.maven.surefire.testng.utils.MethodSelector
- setTestMethods(List) - Method in class org.apache.maven.surefire.testng.utils.MethodSelector
- setTestNGArtifactName(String) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setTestRequest(TestRequest) - Method in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- setTestSetCompletedListener(ForkedProcessReportEventListener<?>) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessEventNotifier
- setTestSetStartingListener(ForkedProcessReportEventListener<T>) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessEventNotifier
- setTestSkippedListener(ForkedProcessReportEventListener<?>) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessEventNotifier
- setTestSourceDirectory(File) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setTestSourceDirectory(File) - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- setTestStartingListener(ForkedProcessReportEventListener<?>) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessEventNotifier
- setTestsToRun(Object) - Method in class org.apache.maven.surefire.junit4.JUnit4Provider
- setTestsToRun(Object) - Method in class org.apache.maven.surefire.junitcore.JUnitCoreProvider
- setTestSucceededListener(ForkedProcessReportEventListener<?>) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessEventNotifier
- setTestSuiteDefinition(Object, TestRequest) - Method in class org.apache.maven.surefire.booter.SurefireReflector
- setTestSuiteDefinitionAware(Object, TestRequest) - Method in class org.apache.maven.surefire.booter.SurefireReflector
- setThreadCount(int) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setThreadCountClasses(int) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setThreadCountMethods(int) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setThreadCountSuites(int) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setToolchainManager(ToolchainManager) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setTrimStackTrace(boolean) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setTrueOptions(SocketOption<Boolean>...) - Method in class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel
- setTrueOptions(SocketOption<Boolean>...) - Method in class org.apache.maven.surefire.booter.spi.SurefireMasterProcessChannelProcessorFactory
- SETUP_METHOD_NAME - Static variable in class org.apache.maven.surefire.junit.PojoTestSetExecutor
- setupBooter(String, String, String, String) - Method in class org.apache.maven.surefire.booter.ForkedBooter
- setUpFixture(Object, PojoTestSetExecutor.DiscoveredTestMethods) - Method in class org.apache.maven.surefire.junit.PojoTestSetExecutor
- setupJunitLogger() - Static method in class org.apache.maven.surefire.junitplatform.JUnitPlatformProvider
- setUpMethod - Variable in class org.apache.maven.surefire.junit.PojoTestSetExecutor.DiscoveredTestMethods
- setupProperties() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setupStuff() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setUseFile(boolean) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setUseFile(boolean) - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- setUseFile(boolean) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setUseManifestOnlyJar(boolean) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setUseManifestOnlyJar(boolean) - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- setUseManifestOnlyJar(boolean) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setUseModulePath(boolean) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setUseModulePath(boolean) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setUseModulePath(boolean) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setUsePhrasedClassNameInRunning(boolean) - Method in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5StatelessTestsetInfoReporter
- setUsePhrasedClassNameInTestCaseSummary(boolean) - Method in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5StatelessTestsetInfoReporter
- setUsePhrasedFileName(boolean) - Method in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5ConsoleOutputReporter
- setUsePhrasedFileName(boolean) - Method in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5StatelessTestsetInfoReporter
- setUsePhrasedFileName(boolean) - Method in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5Xml30StatelessReporter
- setUsePhrasedTestCaseClassName(boolean) - Method in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5Xml30StatelessReporter
- setUsePhrasedTestCaseMethodName(boolean) - Method in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5Xml30StatelessReporter
- setUsePhrasedTestSuiteClassName(boolean) - Method in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5Xml30StatelessReporter
- setUseSystemClassLoader(boolean) - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- setUseSystemClassLoader(boolean) - Method in interface org.apache.maven.plugin.surefire.SurefireExecutionParameters
- setUseSystemClassLoader(boolean) - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- setUseUnlimitedThreads(boolean) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- setValue(V) - Method in class org.apache.maven.surefire.api.util.internal.ImmutableMap.Node
- setVersion(String) - Method in class org.apache.maven.surefire.extensions.StatelessReporter
- setWorkingDirectory(File) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- SharedThreadPoolStrategy - Class in org.apache.maven.surefire.junitcore.pc
-
Parallel strategy for shared thread pool in private package.
- SharedThreadPoolStrategy(ConsoleLogger, ExecutorService) - Constructor for class org.apache.maven.surefire.junitcore.pc.SharedThreadPoolStrategy
- shouldFinish() - Method in class org.apache.maven.surefire.booter.CommandReader.ClassesIterator
- shouldReportToConsole() - Method in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- shouldRun(C, M) - Method in interface org.apache.maven.surefire.api.testset.TestFilter
- shouldRun(Class<?>, String) - Method in class org.apache.maven.surefire.api.testset.TestListResolver
- shouldRun(String, String) - Method in class org.apache.maven.surefire.api.testset.TestListResolver
-
Returns
true
if satisfiestestClassFile
andmethodName
filter. - shouldRun(MethodSource) - Method in class org.apache.maven.surefire.junitplatform.TestMethodFilter
- shouldRun(Description) - Method in class org.apache.maven.surefire.common.junit4.MatchDescriptions
- shouldRun(Description) - Method in class org.apache.maven.surefire.common.junit48.AndFilter
- shouldRun(Description) - Method in class org.apache.maven.surefire.common.junit48.CombinedCategoryFilter
- shouldRun(Description) - Method in class org.apache.maven.surefire.common.junit48.InvertedFilter
- shouldRun(Description) - Method in class org.apache.maven.surefire.common.junit48.MethodFilter
- shouldRun(Description) - Method in class org.apache.maven.surefire.common.junit48.OrFilter
- shouldRun(Description) - Method in class org.apache.maven.surefire.common.junit48.RequestedTest
- shouldRun(Description) - Method in class org.apache.maven.surefire.junit4.TestResolverFilter
- shouldRun(Description) - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC.SuiteFilter
- shouldRun(ITestNGMethod) - Static method in class org.apache.maven.surefire.testng.utils.MethodSelector
- shouldStopQueueing(Event) - Static method in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer
-
Compared item with
ThreadedStreamConsumer.END_ITEM
by identity. - SHOW_ERRORS - Enum constant in enum class org.apache.maven.surefire.api.cli.CommandLineOption
- showArray(T[], String) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- showMap(Map<?, ?>, String) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- showProperties(XMLWriter, Map<String, String>) - Static method in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
-
Adds system properties to the XML report.
- showToLog(SurefireProperties, ConsoleLogger) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- shutdown - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
After the plugin process is shutdown by sending SIGTERM signal (CTRL+C), SHUTDOWN command is received by every forked JVM.
- shutdown - Variable in class org.apache.maven.plugin.surefire.booterclient.Platform
- shutdown - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
After the plugin process is shutdown by sending SIGTERM signal (CTRL+C), SHUTDOWN command is received by every forked JVM.
- shutdown - Variable in class org.apache.maven.surefire.booter.CommandReader
- shutdown - Variable in class org.apache.maven.surefire.booter.ProviderConfiguration
- shutdown - Variable in class org.apache.maven.surefire.junitcore.pc.Scheduler
- shutdown() - Method in class org.apache.maven.surefire.booter.ForkedBooter.PingScheduler
- shutdown(Shutdown) - Method in interface org.apache.maven.plugin.surefire.booterclient.lazytestprovider.NotifiableTestStream
- shutdown(Shutdown) - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream
- shutdown(Shutdown) - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder.CachableCommands
- shutdown(Shutdown) - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder.ImmediateCommands
- shutdown(Shutdown) - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestProvidingInputStream
- Shutdown - Enum Class in org.apache.maven.surefire.api.booter
-
Specifies the way how the forked jvm should be terminated after class AbstractCommandStream is closed and CTRL+C.
- Shutdown(String) - Constructor for enum class org.apache.maven.surefire.api.booter.Shutdown
- SHUTDOWN - Enum constant in enum class org.apache.maven.surefire.api.booter.MasterProcessCommand
- SHUTDOWN - Static variable in class org.apache.maven.surefire.booter.BooterConstants
- SHUTDOWN_HOOK_THREAD_FACTORY - Static variable in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- ShutdownHandler() - Constructor for class org.apache.maven.surefire.junitcore.pc.Scheduler.ShutdownHandler
- shutdownHook - Variable in class org.apache.maven.surefire.extensions.util.CommandlineExecutor
- ShutdownResult - Class in org.apache.maven.surefire.junitcore.pc
-
Populates collection
triggeredTests
of descriptions started before shutting down. - ShutdownResult(Collection<Description>, Collection<Description>) - Constructor for class org.apache.maven.surefire.junitcore.pc.ShutdownResult
- shutdownScheduler - Variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputer
- shutdownStatus - Variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputer
- ShutdownStatus - Class in org.apache.maven.surefire.junitcore.pc
-
Wrapper of
ParallelComputer status information
and tests been populated before a shutdown hook has been triggered. - ShutdownStatus() - Constructor for class org.apache.maven.surefire.junitcore.pc.ShutdownStatus
- shutdownThreadPoolsAwaitingKilled() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputer
- shutdownThreadPoolsAwaitingKilled() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- shutdownThreadPoolsAwaitingKilled() - Method in class org.apache.maven.surefire.junitcore.pc.Scheduler
- shutdownThreadPoolsAwaitingKilled() - Method in class org.apache.maven.surefire.junitcore.pc.SingleThreadScheduler
- SimpleReportEntry - Class in org.apache.maven.surefire.api.report
-
Basic implementation of
TestSetReportEntry
(immutable and thread-safe object). - SimpleReportEntry(RunMode, Long, String, String, String, String) - Constructor for class org.apache.maven.surefire.api.report.SimpleReportEntry
- SimpleReportEntry(RunMode, Long, String, String, String, String, Integer) - Constructor for class org.apache.maven.surefire.api.report.SimpleReportEntry
- SimpleReportEntry(RunMode, Long, String, String, String, String, String) - Constructor for class org.apache.maven.surefire.api.report.SimpleReportEntry
- SimpleReportEntry(RunMode, Long, String, String, String, String, Map<String, String>) - Constructor for class org.apache.maven.surefire.api.report.SimpleReportEntry
- SimpleReportEntry(RunMode, Long, String, String, String, String, StackTraceWriter) - Constructor for class org.apache.maven.surefire.api.report.SimpleReportEntry
- SimpleReportEntry(RunMode, Long, String, String, String, String, StackTraceWriter, Integer) - Constructor for class org.apache.maven.surefire.api.report.SimpleReportEntry
- SimpleReportEntry(RunMode, Long, String, String, String, String, StackTraceWriter, Integer, String, Map<String, String>) - Constructor for class org.apache.maven.surefire.api.report.SimpleReportEntry
- SimpleReportEntry(RunMode, Long, String, String, String, String, StackTraceWriter, Integer, Map<String, String>) - Constructor for class org.apache.maven.surefire.api.report.SimpleReportEntry
- simpleXMLReporter - Variable in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- SingleThreadScheduler - Class in org.apache.maven.surefire.junitcore.pc
-
Used to execute tests annotated with net.jcip.annotations.NotThreadSafe.
- SingleThreadScheduler(ConsoleLogger) - Constructor for class org.apache.maven.surefire.junitcore.pc.SingleThreadScheduler
- SINGLETON - Static variable in class org.apache.maven.plugin.surefire.booterclient.output.InPluginProcessDumpSingleton
- SINGLETON - Static variable in class org.apache.maven.surefire.api.booter.DumpErrorSingleton
- size() - Method in class org.apache.maven.surefire.api.util.DefaultScanResult
- size() - Method in interface org.apache.maven.surefire.api.util.ScanResult
- skip - Variable in class org.apache.maven.plugin.failsafe.VerifyMojo
-
Set this to 'true' to bypass unit tests entirely.
- skip - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Set this to "true" to bypass unit tests entirely.
- SKIP_SINCE_NEXT_TEST - Enum constant in enum class org.apache.maven.surefire.api.booter.MasterProcessCommand
- SKIP_SINCE_NEXT_TEST - Static variable in class org.apache.maven.surefire.api.booter.Command
- skipAfterFailure - Variable in class org.apache.maven.surefire.testng.utils.FailFastEventsSingleton
- skipAfterFailureCount - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
Set to error/failure count in order to skip remaining tests.
- skipAfterFailureCount - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
Set to error/failure count in order to skip remaining tests.
- skipAfterFailureCount - Variable in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- skipAfterFailureCount - Variable in class org.apache.maven.surefire.booter.ProviderConfiguration
- skipAfterFailureCount - Variable in class org.apache.maven.surefire.common.junit4.Notifier
- skipAfterFailureCount - Variable in class org.apache.maven.surefire.testng.TestNGDirectoryTestSuite
- skipAfterFailureCount - Variable in class org.apache.maven.surefire.testng.TestNGXmlTestSuite
- skipExec - Variable in class org.apache.maven.plugin.failsafe.VerifyMojo
-
Deprecated.Use -DskipTests instead.
- skipExec - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Deprecated.Use skipTests instead.
- skipITs - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
Set this to "true" to skip running integration tests, but still compile them.
- skipITs - Variable in class org.apache.maven.plugin.failsafe.VerifyMojo
-
Set this to 'true' to skip running integration tests, but still compile them.
- skipped - Enum constant in enum class org.apache.maven.plugin.surefire.report.DefaultReporterFactory.TestResultType
- skipped - Variable in class org.apache.maven.plugin.surefire.report.TestSetStats
- skipped - Variable in class org.apache.maven.surefire.api.suite.RunResult
- skipped - Variable in class org.apache.maven.surefire.report.RunStatistics
- SKIPPED - Enum constant in enum class org.apache.maven.plugin.surefire.report.ReportEntryType
- SKIPPED - Static variable in class org.apache.maven.plugin.surefire.report.TestSetStats
- skipSinceNextTest() - Method in interface org.apache.maven.plugin.surefire.booterclient.lazytestprovider.NotifiableTestStream
-
Sends an event to a fork jvm in order to skip tests.
- skipSinceNextTest() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream
- skipSinceNextTest() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder.CachableCommands
- skipSinceNextTest() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder.ImmediateCommands
- skipSinceNextTest() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestProvidingInputStream
- skipTests - Variable in class org.apache.maven.plugin.failsafe.VerifyMojo
-
Set this to 'true' to skip running tests, but still compile them.
- skipTests - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Set this to "true" to skip running tests, but still compile them.
- slave - Variable in class org.apache.maven.surefire.junitcore.pc.Scheduler.Controller
- slaves - Variable in class org.apache.maven.surefire.junitcore.pc.Scheduler
- SmartStackTraceParser - Class in org.apache.maven.surefire.report
- SmartStackTraceParser(String, Throwable, String) - Constructor for class org.apache.maven.surefire.report.SmartStackTraceParser
- smartTrimmed - Variable in class org.apache.maven.plugin.surefire.booterclient.output.DeserializedStacktraceWriter
- smartTrimmedStackTrace - Variable in class org.apache.maven.surefire.booter.spi.EventChannelEncoder.StackTrace
- smartTrimmedStackTrace() - Method in class org.apache.maven.plugin.surefire.booterclient.output.DeserializedStacktraceWriter
- smartTrimmedStackTrace() - Method in class org.apache.maven.surefire.api.report.LegacyPojoStackTraceWriter
- smartTrimmedStackTrace() - Method in interface org.apache.maven.surefire.api.report.StackTraceWriter
-
Get the "smart" trimmed (1-2 lines) stacktrace.
- smartTrimmedStackTrace() - Method in class org.apache.maven.surefire.common.junit4.JUnit4StackTraceWriter
- smartTrimmedStackTrace() - Method in class org.apache.maven.surefire.report.PojoStackTraceWriter
- sortOrder - Variable in class org.apache.maven.surefire.api.util.DefaultRunOrderCalculator
- source - Variable in class org.apache.maven.surefire.api.report.SimpleReportEntry
- SOURCE_DIRECTORY - Static variable in class org.apache.maven.surefire.booter.BooterConstants
- sourceText - Variable in class org.apache.maven.surefire.api.report.SimpleReportEntry
- SPECIFIC_TEST_PROPERTY_PREFIX - Static variable in class org.apache.maven.surefire.booter.BooterConstants
- SpecificFileFilter - Class in org.apache.maven.plugin.surefire.util
-
Deprecated.
- SpecificFileFilter(String[]) - Constructor for class org.apache.maven.plugin.surefire.util.SpecificFileFilter
-
Deprecated.
- SpecificTestClassFilter - Class in org.apache.maven.surefire.api.filter
-
Filter for test class files
- SpecificTestClassFilter(String[]) - Constructor for class org.apache.maven.surefire.api.filter.SpecificTestClassFilter
- specificTests - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- specificTests - Variable in class org.apache.maven.surefire.api.testset.DirectoryScannerParameters
-
Deprecated.
- specificTests - Variable in class org.apache.maven.surefire.api.util.DefaultDirectoryScanner
-
Deprecated.
- split(String, String) - Static method in class org.apache.maven.surefire.api.util.internal.StringUtils
- splitPool - Variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- stackTrace - Variable in class org.apache.maven.plugin.surefire.booterclient.output.DeserializedStacktraceWriter
- stackTrace - Variable in class org.apache.maven.surefire.booter.spi.EventChannelEncoder.StackTrace
- stackTrace - Variable in class org.apache.maven.surefire.report.SmartStackTraceParser
- StackTrace(StackTraceWriter, boolean) - Constructor for class org.apache.maven.surefire.booter.spi.EventChannelEncoder.StackTrace
- StackTraceFilter - Interface in org.apache.maven.surefire.report
-
StackTrace element filter.
- stackTraceWithFocusOnClassAsString(Throwable, String) - Static method in class org.apache.maven.surefire.report.SmartStackTraceParser
- stackTraceWriter - Variable in class org.apache.maven.plugin.surefire.report.TestMethodStats
- stackTraceWriter - Variable in class org.apache.maven.surefire.api.event.ConsoleErrorEvent
- stackTraceWriter - Variable in class org.apache.maven.surefire.api.event.JvmExitErrorEvent
- stackTraceWriter - Variable in class org.apache.maven.surefire.api.report.SimpleReportEntry
- StackTraceWriter - Interface in org.apache.maven.surefire.api.report
-
Ability to write a stack trace, filtered to omit locations inside Surefire and Maven.
- StandardStreamErrEvent - Class in org.apache.maven.surefire.api.event
-
The event of standard error stream.
- StandardStreamErrEvent(RunMode, Long, String) - Constructor for class org.apache.maven.surefire.api.event.StandardStreamErrEvent
- StandardStreamErrWithNewLineEvent - Class in org.apache.maven.surefire.api.event
-
The event of standard error stream with new line.
- StandardStreamErrWithNewLineEvent(RunMode, Long, String) - Constructor for class org.apache.maven.surefire.api.event.StandardStreamErrWithNewLineEvent
- StandardStreamOutEvent - Class in org.apache.maven.surefire.api.event
-
The event of standard output stream.
- StandardStreamOutEvent(RunMode, Long, String) - Constructor for class org.apache.maven.surefire.api.event.StandardStreamOutEvent
- StandardStreamOutWithNewLineEvent - Class in org.apache.maven.surefire.api.event
-
The event of standard output stream with new line.
- StandardStreamOutWithNewLineEvent(RunMode, Long, String) - Constructor for class org.apache.maven.surefire.api.event.StandardStreamOutWithNewLineEvent
- START_TEST - Static variable in class org.apache.maven.surefire.junit.TestListenerInvocationHandler
- START_TIME_NEGATIVE_TIMEOUT - Static variable in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
- START_TIME_ZERO - Static variable in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
- startCapture(TestOutputReceiver<OutputReportEntry>) - Static method in class org.apache.maven.surefire.api.report.ConsoleOutputCapture
- started - Variable in class org.apache.maven.surefire.junitcore.pc.Scheduler
- STARTED - Enum constant in enum class org.apache.maven.surefire.junitcore.pc.ExecutionStatus
- startMonitor - Variable in class org.apache.maven.surefire.booter.CommandReader
- startsWith(StringBuffer, String) - Static method in class org.apache.maven.surefire.api.util.internal.StringUtils
-
Determines if
buffer
starts with specific literal(s). - startTestElement(XMLWriter, WrappedReportEntry) - Method in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- startTestSuite(RunListener) - Method in class org.apache.maven.surefire.testng.TestSuite
- startTime - Variable in class org.apache.maven.surefire.junitcore.TestMethod
-
Deprecated.
- startupConfig - Variable in class org.apache.maven.plugin.surefire.InPluginVMSurefireStarter
- startupConfiguration - Variable in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- startupConfiguration - Variable in class org.apache.maven.surefire.booter.ForkedBooter
- startupConfiguration - Variable in class org.apache.maven.surefire.booter.ProviderFactory
- StartupConfiguration - Class in org.apache.maven.surefire.booter
-
Configuration that is used by the SurefireStarter but does not make it into the provider itself.
- StartupConfiguration(String, AbstractPathConfiguration, ClassLoaderConfiguration, ProcessCheckerType, List<String[]>) - Constructor for class org.apache.maven.surefire.booter.StartupConfiguration
- startupReportConfig - Variable in class org.apache.maven.plugin.surefire.InPluginVMSurefireStarter
- startupReportConfiguration - Variable in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- startupReportConfiguration - Variable in class org.apache.maven.plugin.surefire.CommonReflector
- StartupReportConfiguration - Class in org.apache.maven.plugin.surefire
-
All the parameters used to construct reporters
- StartupReportConfiguration(boolean, boolean, String, boolean, File, boolean, String, File, boolean, int, String, String, boolean, SurefireStatelessReporter, SurefireConsoleOutputReporter, SurefireStatelessTestsetInfoReporter) - Constructor for class org.apache.maven.plugin.surefire.StartupReportConfiguration
- state - Variable in class org.apache.maven.surefire.booter.CommandReader
- StatelessReporter<R extends TestSetReportEntry,
S, C extends StatelessReportMojoConfiguration> - Class in org.apache.maven.surefire.extensions -
Extension for stateless reporter.
- StatelessReporter() - Constructor for class org.apache.maven.surefire.extensions.StatelessReporter
- StatelessReportEventListener<R extends TestSetReportEntry,
S> - Interface in org.apache.maven.surefire.extensions -
Creates a report upon handled event "testSetCompleted".
- StatelessReportMojoConfiguration - Class in org.apache.maven.surefire.extensions
-
Configuration passed to the constructor of default reporter org.apache.maven.plugin.surefire.report.StatelessXmlReporter.
- StatelessReportMojoConfiguration(File, String, boolean, int, String) - Constructor for class org.apache.maven.surefire.extensions.StatelessReportMojoConfiguration
- StatelessTestsetInfoConsoleReportEventListener<R extends TestSetReportEntry,
S> - Class in org.apache.maven.surefire.extensions -
Extension listener for stateless console reporter of test-set.
- StatelessTestsetInfoConsoleReportEventListener(ConsoleLogger) - Constructor for class org.apache.maven.surefire.extensions.StatelessTestsetInfoConsoleReportEventListener
- StatelessTestsetInfoFileReportEventListener<R extends TestSetReportEntry,
S> - Class in org.apache.maven.surefire.extensions -
Extension listener for stateless file reporter of test-set.
- StatelessTestsetInfoFileReportEventListener(File, String, Charset) - Constructor for class org.apache.maven.surefire.extensions.StatelessTestsetInfoFileReportEventListener
- statelessTestsetInfoReporter - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- statelessTestsetInfoReporter - Variable in class org.apache.maven.plugin.surefire.CommonReflector
- StatelessTestsetInfoReporter<R extends TestSetReportEntry,
S> - Class in org.apache.maven.surefire.extensions -
Extension listener for stateless file and console reporter of test-set.
- StatelessTestsetInfoReporter() - Constructor for class org.apache.maven.surefire.extensions.StatelessTestsetInfoReporter
- statelessTestsetReporter - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Note: use the legacy system property disableXmlReport set to
true
to disable the report. - statelessTestsetReporter - Variable in class org.apache.maven.plugin.surefire.CommonReflector
- StatelessXmlReporter - Class in org.apache.maven.plugin.surefire.report
- StatelessXmlReporter(File, String, boolean, int, Map<String, Deque<WrappedReportEntry>>, String, String, boolean, boolean, boolean, boolean) - Constructor for class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- StatelessXmlReporter.ByteConstantsHolder - Class in org.apache.maven.plugin.surefire.report
- StatelessXmlReporter.EncodingOutputStream - Class in org.apache.maven.plugin.surefire.report
- statisticsFile - Variable in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- statisticsReporter - Variable in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- statisticsReporter - Variable in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- StatisticsReporter - Class in org.apache.maven.plugin.surefire.runorder
- StatisticsReporter(File) - Constructor for class org.apache.maven.plugin.surefire.runorder.StatisticsReporter
- StatisticsReporter(File, RunEntryStatisticsMap, RunEntryStatisticsMap) - Constructor for class org.apache.maven.plugin.surefire.runorder.StatisticsReporter
- status - Variable in class org.apache.maven.surefire.junitcore.pc.ShutdownStatus
- stdErr - Variable in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- stdErr(String) - Static method in class org.apache.maven.surefire.api.report.TestOutputReportEntry
- stdErrChannel - Variable in class org.apache.maven.surefire.extensions.util.CommandlineStreams
- StdErrListener() - Constructor for class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.StdErrListener
- stdErrln(String) - Static method in class org.apache.maven.surefire.api.report.TestOutputReportEntry
- stdInChannel - Variable in class org.apache.maven.surefire.extensions.util.CommandlineStreams
- stdout - Variable in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- stdOut(String) - Static method in class org.apache.maven.surefire.api.report.TestOutputReportEntry
- stdOutChannel - Variable in class org.apache.maven.surefire.extensions.util.CommandlineStreams
- stdOutErrEventListeners - Variable in class org.apache.maven.plugin.surefire.booterclient.output.ForkedProcessEventNotifier
- StdOutListener() - Constructor for class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.StdOutListener
- stdOutln(String) - Static method in class org.apache.maven.surefire.api.report.TestOutputReportEntry
- stop - Variable in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer
- stop() - Method in class org.apache.maven.surefire.booter.CommandReader
- stop() - Method in class org.apache.maven.surefire.booter.PpidChecker
- stop() - Method in class org.apache.maven.surefire.junitcore.pc.AbstractThreadPoolStrategy
- stop() - Method in class org.apache.maven.surefire.junitcore.pc.InvokerStrategy
- stop() - Method in class org.apache.maven.surefire.junitcore.pc.SchedulingStrategy
-
Stops scheduling new tasks (e.g.
- stop() - Method in class org.apache.maven.surefire.junitcore.pc.SharedThreadPoolStrategy
- stop(boolean) - Method in class org.apache.maven.surefire.junitcore.pc.SharedThreadPoolStrategy
- stop(Collection<Description>, Collection<Description>, boolean, boolean) - Method in class org.apache.maven.surefire.junitcore.pc.Scheduler.Controller
- stop(Collection<Description>, Collection<Description>, boolean, boolean) - Method in class org.apache.maven.surefire.junitcore.pc.Scheduler
-
Stop/Shutdown/Interrupt scheduler and its children (if any).
- stopItemMarker - Variable in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.QueueSynchronizer
- stopNow() - Method in class org.apache.maven.surefire.junitcore.pc.AbstractThreadPoolStrategy
- stopNow() - Method in class org.apache.maven.surefire.junitcore.pc.InvokerStrategy
- stopNow() - Method in class org.apache.maven.surefire.junitcore.pc.SchedulingStrategy
-
Stops scheduling new tasks and
interrupts
running tasks (e.g. - stopNow() - Method in class org.apache.maven.surefire.junitcore.pc.SharedThreadPoolStrategy
- stopOnNextTest() - Method in interface org.apache.maven.surefire.api.booter.MasterProcessChannelEncoder
-
The provider wants to stop the progress.
- stopOnNextTest() - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- stoppable - Variable in class org.apache.maven.surefire.testng.utils.FailFastListener
- Stoppable - Interface in org.apache.maven.surefire.extensions
-
Used in
CloseableDaemonThread
. - Stoppable - Interface in org.apache.maven.surefire.testng.utils
-
Covers configuration parameter
skipAfterFailureCount
. - stopped - Variable in class org.apache.maven.surefire.booter.PpidChecker
- storage - Variable in class org.apache.maven.plugin.surefire.report.Utf8RecodingDeferredFileOutputStream
- strategy - Variable in class org.apache.maven.surefire.junitcore.pc.Scheduler
- stream - Variable in class org.apache.maven.plugin.surefire.log.api.PrintStreamLogger
- STREAM_BUFFER_SIZE - Static variable in class org.apache.maven.plugin.surefire.report.ConsoleOutputFileReporter
- STREAM_FLUSHER - Static variable in class org.apache.maven.surefire.booter.spi.AbstractMasterProcessChannelProcessorFactory
- StreamFeeder - Class in org.apache.maven.plugin.surefire.extensions
-
Commands which are sent from plugin to the forked jvm.
- StreamFeeder(String, WritableByteChannel, CommandReader, ConsoleLogger) - Constructor for class org.apache.maven.plugin.surefire.extensions.StreamFeeder
- StreamReadStatus() - Constructor for enum class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.StreamReadStatus
- STRING_ENCODING - Enum constant in enum class org.apache.maven.surefire.api.stream.SegmentType
- StringUtils - Class in org.apache.maven.surefire.api.util.internal
-
Common
java.lang.String
manipulation routines. - StringUtils() - Constructor for class org.apache.maven.surefire.api.util.internal.StringUtils
- stripEnd(String, String) - Static method in class org.apache.maven.surefire.booter.StartupConfiguration
-
Strip any of a supplied String from the end of a String.
- stripIllegalFilenameChars(String) - Static method in class org.apache.maven.plugin.surefire.report.FileReporterUtils
- stripNewLines(String) - Static method in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- success - Enum constant in enum class org.apache.maven.plugin.surefire.report.DefaultReporterFactory.TestResultType
- success(String) - Method in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
- SUCCESS - Enum constant in enum class org.apache.maven.plugin.surefire.log.api.Level
-
defaults to bold, red
- SUCCESS - Enum constant in enum class org.apache.maven.plugin.surefire.report.ReportEntryType
- SUCCESS - Static variable in class org.apache.maven.surefire.api.suite.RunResult
- successfulBuilds - Variable in class org.apache.maven.surefire.api.runorder.RunEntryStatistics
- SuiteAndNamedTests() - Constructor for class org.apache.maven.surefire.testng.TestNGExecutor.SuiteAndNamedTests
- suiteFilePaths - Variable in class org.apache.maven.surefire.testng.TestNGXmlTestSuite
- suiteFiles - Variable in class org.apache.maven.surefire.testng.TestNGXmlTestSuite
- SuiteFilter() - Constructor for class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC.SuiteFilter
- suiteName - Variable in class org.apache.maven.surefire.testng.TestNGExecutor.TestMetadata
- suites - Variable in class org.apache.maven.surefire.junitcore.pc.Concurrency
- suites - Variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- suites - Variable in class org.apache.maven.surefire.junitcore.pc.RunnerCounter
- SUITES - Enum constant in enum class org.apache.maven.surefire.junitcore.pc.Type
- suiteXmlFiles - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
(TestNG) List of <suiteXmlFile> elements specifying TestNG suite xml file locations.
- suiteXmlFiles - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
(TestNG) List of <suiteXmlFile> elements specifying TestNG suite xml file locations.
- suiteXmlFiles - Variable in class org.apache.maven.surefire.api.testset.TestRequest
- suiteXmlFiles() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- suiteXmlFiles() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Calls
AbstractSurefireMojo.getSuiteXmlFiles()
aslist
. - suiteXmlFiles() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- summaryFile - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
The summary file to write integration test results to.
- summaryFile - Variable in class org.apache.maven.plugin.failsafe.VerifyMojo
-
The summary file to read integration test results from.
- summaryFiles - Variable in class org.apache.maven.plugin.failsafe.VerifyMojo
-
Additional summary files to read integration test results from.
- sumThreadCounts(Concurrency) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerUtil
- SUREFIRE_CLASSPATH - Static variable in class org.apache.maven.surefire.booter.AbstractPathConfiguration
- SUREFIRE_TEST_CLASSPATH - Static variable in class org.apache.maven.surefire.booter.StartupConfiguration
- SurefireBooterForkException - Exception in org.apache.maven.surefire.booter
-
Encapsulates exceptions thrown during Surefire forking.
- SurefireBooterForkException(String) - Constructor for exception org.apache.maven.surefire.booter.SurefireBooterForkException
- SurefireBooterForkException(String, String, Throwable, RunResult) - Constructor for exception org.apache.maven.surefire.booter.SurefireBooterForkException
- SurefireBooterForkException(String, Throwable) - Constructor for exception org.apache.maven.surefire.booter.SurefireBooterForkException
- SurefireBooterForkException(String, RunResult) - Constructor for exception org.apache.maven.surefire.booter.SurefireBooterForkException
- surefireClassLoader - Variable in class org.apache.maven.plugin.surefire.CommonReflector
- surefireClassLoader - Variable in class org.apache.maven.surefire.booter.SurefireReflector
- surefireClasspathUrls - Variable in class org.apache.maven.surefire.booter.AbstractPathConfiguration
- SurefireConsoleOutputReporter - Class in org.apache.maven.plugin.surefire.extensions
-
Default implementation for extension of console logger.
- SurefireConsoleOutputReporter() - Constructor for class org.apache.maven.plugin.surefire.extensions.SurefireConsoleOutputReporter
- surefireDependencyResolver - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- SurefireDependencyResolver - Class in org.apache.maven.plugin.surefire
-
Does dependency resolution and artifact handling for the surefire plugin.
- SurefireDependencyResolver(RepositorySystem, ConsoleLogger, ArtifactRepository, List<ArtifactRepository>, List<ArtifactRepository>, ResolutionErrorHandler, String, boolean) - Constructor for class org.apache.maven.plugin.surefire.SurefireDependencyResolver
- SurefireDependencyResolver.RuntimeArtifactFilter - Class in org.apache.maven.plugin.surefire
- SurefireExecutionException - Exception in org.apache.maven.surefire.booter
-
An error occurring during the invocation of Surefire via an alternate class loader.
- SurefireExecutionException(String, Throwable) - Constructor for exception org.apache.maven.surefire.booter.SurefireExecutionException
- SurefireExecutionParameters - Interface in org.apache.maven.plugin.surefire
-
This interface contains all the common parameters that have different implementations in Surefire vs IntegrationTest
- SurefireForkChannel - Class in org.apache.maven.plugin.surefire.extensions
-
The TCP/IP server accepting only one client connection.
- SurefireForkChannel(ForkNodeArguments) - Constructor for class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel
- SurefireForkChannel.Bindings - Class in org.apache.maven.plugin.surefire.extensions
- SurefireForkChannel.CommandBindings - Class in org.apache.maven.plugin.surefire.extensions
- SurefireForkChannel.EventBindings - Class in org.apache.maven.plugin.surefire.extensions
- SurefireForkNodeFactory - Class in org.apache.maven.plugin.surefire.extensions
-
The factory of
SurefireForkChannel
. - SurefireForkNodeFactory() - Constructor for class org.apache.maven.plugin.surefire.extensions.SurefireForkNodeFactory
- SurefireHelper - Class in org.apache.maven.plugin.surefire
-
Helper class for surefire plugins
- SurefireHelper() - Constructor for class org.apache.maven.plugin.surefire.SurefireHelper
-
Do not instantiate.
- SurefireMasterProcessChannelProcessorFactory - Class in org.apache.maven.surefire.booter.spi
-
Producer of TCP/IP encoder and decoder.
- SurefireMasterProcessChannelProcessorFactory() - Constructor for class org.apache.maven.surefire.booter.spi.SurefireMasterProcessChannelProcessorFactory
- SurefirePlugin - Class in org.apache.maven.plugin.surefire
-
Run tests using Surefire.
- SurefirePlugin() - Constructor for class org.apache.maven.plugin.surefire.SurefirePlugin
- SurefireProperties - Class in org.apache.maven.plugin.surefire
-
A properties implementation that preserves insertion order.
- SurefireProperties() - Constructor for class org.apache.maven.plugin.surefire.SurefireProperties
- SurefireProperties(Properties) - Constructor for class org.apache.maven.plugin.surefire.SurefireProperties
- SurefireProperties(KeyValueSource) - Constructor for class org.apache.maven.plugin.surefire.SurefireProperties
- SurefireProvider - Interface in org.apache.maven.surefire.api.provider
-
Interface to be implemented by all Surefire providers.
- SurefireReflectionException - Exception in org.apache.maven.surefire.api.util
-
Exception indicating that surefire had problems with reflection.
- SurefireReflectionException(Throwable) - Constructor for exception org.apache.maven.surefire.api.util.SurefireReflectionException
-
Create a
SurefireReflectionException
with the specified cause. - surefireReflector - Variable in class org.apache.maven.surefire.booter.ProviderFactory
- SurefireReflector - Class in org.apache.maven.surefire.booter
-
Does reflection based invocation of the surefire methods.
- SurefireReflector(ClassLoader) - Constructor for class org.apache.maven.surefire.booter.SurefireReflector
- SurefireReportParameters - Interface in org.apache.maven.plugin.surefire
-
The parameters required to report on a surefire execution.
- SurefireStatelessReporter - Class in org.apache.maven.plugin.surefire.extensions
-
Default implementation for extension of
StatelessXmlReporter
in plugin. - SurefireStatelessReporter() - Constructor for class org.apache.maven.plugin.surefire.extensions.SurefireStatelessReporter
-
Activated in the injection point of MOJO.
- SurefireStatelessReporter(boolean, String) - Constructor for class org.apache.maven.plugin.surefire.extensions.SurefireStatelessReporter
-
Activated if null injection point in MOJO.
- SurefireStatelessTestsetInfoReporter - Class in org.apache.maven.plugin.surefire.extensions
-
Default implementation for extension of
test-set event listener for stateless file and console reporter
in plugin. - SurefireStatelessTestsetInfoReporter() - Constructor for class org.apache.maven.plugin.surefire.extensions.SurefireStatelessTestsetInfoReporter
- SurefireTestSetExecutor - Interface in org.apache.maven.surefire.junit
-
Describes a single test set
- swapClassLoader(ClassLoader) - Method in class org.apache.maven.surefire.booter.ProviderFactory.ProviderProxy
- sync() - Method in class org.apache.maven.plugin.surefire.report.Utf8RecodingDeferredFileOutputStream
- synchronizer - Variable in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer
- SynchronousRunner - Class in org.apache.maven.surefire.junitcore
-
Deprecated.
- SynchronousRunner() - Constructor for class org.apache.maven.surefire.junitcore.SynchronousRunner
-
Deprecated.
- SyncT1() - Constructor for class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.QueueSynchronizer.SyncT1
- SyncT2() - Constructor for class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.QueueSynchronizer.SyncT2
- SYSTEM_EXIT_TIMEOUT - Static variable in class org.apache.maven.surefire.booter.BooterConstants
- SYSTEM_PATH_TO_WMIC - Static variable in class org.apache.maven.surefire.booter.PpidChecker
- SYSTEM_PROPERTIES_FILE_COUNTER - Static variable in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- systemExitTimeout - Variable in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- systemExitTimeout - Variable in class org.apache.maven.surefire.booter.ProviderConfiguration
- systemExitTimeout(long) - Method in class org.apache.maven.surefire.booter.ProviderConfiguration
- systemExitTimeoutInSeconds - Variable in class org.apache.maven.surefire.booter.ForkedBooter
- systemProperties - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Deprecated.Use systemPropertyVariables instead.
- systemProperties - Variable in class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- systemProperties - Variable in class org.apache.maven.surefire.api.report.SimpleReportEntry
- systemPropertiesFile - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- systemPropertiesFile - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
- SystemPropertiesListener() - Constructor for class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.SystemPropertiesListener
- systemPropertiesMatchingArgLine(SurefireProperties) - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- SystemPropertyEvent - Class in org.apache.maven.surefire.api.event
-
The event of system property.
- SystemPropertyEvent(RunMode, Long, String, String) - Constructor for class org.apache.maven.surefire.api.event.SystemPropertyEvent
- SystemPropertyManager - Class in org.apache.maven.surefire.booter
- SystemPropertyManager() - Constructor for class org.apache.maven.surefire.booter.SystemPropertyManager
- systemPropertyVariables - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
List of System properties to pass to the JUnit tests.
- systemProps() - Static method in class org.apache.maven.surefire.api.util.internal.ObjectUtils
- SystemUtils - Class in org.apache.maven.surefire.booter
-
JDK 9 support.
- SystemUtils() - Constructor for class org.apache.maven.surefire.booter.SystemUtils
T
- t - Variable in class org.apache.maven.surefire.api.report.LegacyPojoStackTraceWriter
- t - Variable in class org.apache.maven.surefire.report.PojoStackTraceWriter
- t1 - Variable in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.QueueSynchronizer
- t2 - Variable in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.QueueSynchronizer
- target - Variable in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.Pumper
- target - Variable in class org.apache.maven.surefire.api.booter.ForkingRunListener
- target - Variable in class org.apache.maven.surefire.api.report.ConsoleOutputCapture.ForwardingPrintStream
- target - Variable in class org.apache.maven.surefire.api.report.SafeThrowable
- TEARDOWN_METHOD_NAME - Static variable in class org.apache.maven.surefire.junit.PojoTestSetExecutor
- tearDownFixture(Object, PojoTestSetExecutor.DiscoveredTestMethods) - Method in class org.apache.maven.surefire.junit.PojoTestSetExecutor
- tearDownMethod - Variable in class org.apache.maven.surefire.junit.PojoTestSetExecutor.DiscoveredTestMethods
- tempDir - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Relative path to temporary-surefire-boot directory containing internal Surefire temporary files.
- tempDirectory - Variable in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- test - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- test - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
- test - Variable in class org.apache.maven.surefire.common.junit48.RequestedTest
- TEST - Static variable in class org.apache.maven.surefire.common.junit3.JUnit3Reflector
- TEST_CASE - Static variable in class org.apache.maven.surefire.common.junit3.JUnit3Reflector
- TEST_CLASSES_DIRECTORY - Static variable in class org.apache.maven.surefire.booter.BooterConstants
- TEST_LISTENER - Static variable in class org.apache.maven.surefire.common.junit3.JUnit3Reflector
- TEST_METHOD - Static variable in class org.apache.maven.surefire.junitcore.TestMethod
-
Deprecated.
- TEST_METHOD_PREFIX - Static variable in class org.apache.maven.surefire.junit.PojoTestSetExecutor
- TEST_RESULT - Static variable in class org.apache.maven.surefire.common.junit3.JUnit3Reflector
- TEST_RUN_ID - Enum constant in enum class org.apache.maven.surefire.api.stream.SegmentType
- TEST_SET - Static variable in class org.apache.maven.surefire.junitcore.TestSet
-
Deprecated.
- TEST_SET_FINISHED - Enum constant in enum class org.apache.maven.surefire.api.booter.MasterProcessCommand
- TEST_SET_FINISHED - Static variable in class org.apache.maven.surefire.api.booter.Command
- TEST_SET_STARTING_PREFIX - Static variable in class org.apache.maven.plugin.surefire.report.ConsoleReporter
- TEST_SUITE - Static variable in class org.apache.maven.surefire.common.junit3.JUnit3Reflector
- TEST_SUITE_XML_FILES - Static variable in class org.apache.maven.surefire.booter.BooterConstants
- testArtifact - Variable in class org.apache.maven.surefire.booter.ProviderConfiguration
- TESTARTIFACT_CLASSIFIER - Static variable in class org.apache.maven.surefire.booter.BooterConstants
- TESTARTIFACT_VERSION - Static variable in class org.apache.maven.surefire.booter.BooterConstants
- testArtifactInfo - Variable in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- testArtifactInfo - Variable in class org.apache.maven.surefire.booter.SurefireReflector
- TestArtifactInfo - Class in org.apache.maven.surefire.api.testset
-
Contains information about the detected test artifact
- TestArtifactInfo(String, String) - Constructor for class org.apache.maven.surefire.api.testset.TestArtifactInfo
- testAssumption - Variable in class org.apache.maven.surefire.junitcore.TestMethod
-
Deprecated.
- testAssumption(ReportEntry) - Method in class org.apache.maven.surefire.junitcore.TestMethod
-
Deprecated.
- testAssumptionFailure(ReportEntry) - Method in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- testAssumptionFailure(ReportEntry) - Method in class org.apache.maven.surefire.api.booter.ForkingRunListener
- testAssumptionFailure(ReportEntry) - Method in interface org.apache.maven.surefire.api.report.RunListener
-
Event fired when a test assumption failure was encountered.
- testAssumptionFailure(ReportEntry) - Method in class org.apache.maven.surefire.junit.JUnit3Reporter
- testAssumptionFailure(ReportEntry) - Method in class org.apache.maven.surefire.junitcore.ConcurrentRunListener
-
Deprecated.
- testAssumptionFailure(ReportEntry, boolean) - Method in interface org.apache.maven.surefire.api.booter.MasterProcessChannelEncoder
-
The test assumption failure.
- testAssumptionFailure(ReportEntry, boolean) - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- testAssumptionFailure(Failure) - Method in class org.apache.maven.surefire.common.junit4.JUnit4RunListener
- testAssumptionFailure(Failure) - Method in class org.apache.maven.surefire.junitcore.NonConcurrentRunListener
-
Deprecated.
- TestAssumptionFailureEvent - Class in org.apache.maven.surefire.api.event
-
The event for the failed assumption.
- TestAssumptionFailureEvent(ReportEntry) - Constructor for class org.apache.maven.surefire.api.event.TestAssumptionFailureEvent
- TestAssumptionFailureListener() - Constructor for class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.TestAssumptionFailureListener
- testCase - Variable in class org.apache.maven.surefire.common.junit3.JUnit3Reflector
- testChecker - Variable in class org.apache.maven.surefire.junit.JUnit3Provider
- testClass - Variable in class org.apache.maven.surefire.api.report.LegacyPojoStackTraceWriter
- testClass - Variable in class org.apache.maven.surefire.report.PojoStackTraceWriter
- testClass - Variable in class org.apache.maven.surefire.report.SmartStackTraceParser
- testClasses - Variable in class org.apache.maven.surefire.booter.CommandReader
- testClassesDirectory - Variable in class org.apache.maven.plugin.failsafe.VerifyMojo
-
The directory containing generated test classes of the project being tested.
- testClassesDirectory - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
The directory containing generated test classes of the project being tested.
- testClassesDirectory - Variable in class org.apache.maven.plugin.surefire.TestClassPath
- testClassesDirectory - Variable in class org.apache.maven.surefire.api.testset.DirectoryScannerParameters
- testClassLoader - Variable in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- testClassLoader - Variable in class org.apache.maven.surefire.junit.JUnit3Provider
- testClassLoader - Variable in class org.apache.maven.surefire.junit4.JUnit4Provider
- testClassLoader - Variable in class org.apache.maven.surefire.junitcore.JUnitCoreProvider
- testClassLoader - Variable in class org.apache.maven.surefire.testng.TestNGProvider
- testClassMethodName - Variable in class org.apache.maven.plugin.surefire.report.TestMethodStats
- TestClassMethodNameUtils - Class in org.apache.maven.surefire.api.util.internal
-
JUnit Description parser.
- TestClassMethodNameUtils() - Constructor for class org.apache.maven.surefire.api.util.internal.TestClassMethodNameUtils
- testClassMethodRunHistory - Variable in class org.apache.maven.plugin.surefire.extensions.DefaultStatelessReportMojoConfiguration
-
Deprecated.
- testClassMethodRunHistory - Variable in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- testClassMethodRunHistoryMap - Variable in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- testClassName - Variable in class org.apache.maven.surefire.junitcore.TestSet
-
Deprecated.
- testClassName - Variable in class org.apache.maven.surefire.report.SmartStackTraceParser
- testClassNames - Variable in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestProvidingInputStream
- testClassNames - Variable in class org.apache.maven.surefire.common.junit4.Notifier
- testClasspath - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.JUnitPlatformProviderInfo
- TestClassPath - Class in org.apache.maven.plugin.surefire
- TestClassPath(Iterable<Artifact>, File, File, String[]) - Constructor for class org.apache.maven.plugin.surefire.TestClassPath
- testClasspathUrls - Variable in class org.apache.maven.surefire.booter.ClasspathConfiguration
- testClasspathUrls - Variable in class org.apache.maven.surefire.booter.ModularClasspathConfiguration
- TestcycleConsoleOutputReceiver - Interface in org.apache.maven.plugin.surefire.report
- testError - Variable in class org.apache.maven.surefire.junitcore.TestMethod
-
Deprecated.
- testError(WrappedReportEntry) - Method in class org.apache.maven.plugin.surefire.report.TestSetStats
- testError(ReportEntry) - Method in class org.apache.maven.plugin.surefire.report.NullStatisticsReporter
- testError(ReportEntry) - Method in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- testError(ReportEntry) - Method in class org.apache.maven.plugin.surefire.runorder.StatisticsReporter
- testError(ReportEntry) - Method in class org.apache.maven.surefire.api.booter.ForkingRunListener
- testError(ReportEntry) - Method in interface org.apache.maven.surefire.api.report.RunListener
-
Event fired when a test ended with an error (non anticipated problem)
- testError(ReportEntry) - Method in class org.apache.maven.surefire.junit.JUnit3Reporter
- testError(ReportEntry) - Method in class org.apache.maven.surefire.junitcore.ConcurrentRunListener
-
Deprecated.
- testError(ReportEntry) - Method in class org.apache.maven.surefire.junitcore.TestMethod
-
Deprecated.
- testError(ReportEntry, boolean) - Method in interface org.apache.maven.surefire.api.booter.MasterProcessChannelEncoder
-
The test error.
- testError(ReportEntry, boolean) - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- TestErrorEvent - Class in org.apache.maven.surefire.api.event
-
The event for the erroneous test.
- TestErrorEvent(ReportEntry) - Constructor for class org.apache.maven.surefire.api.event.TestErrorEvent
- TestErrorListener() - Constructor for class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.TestErrorListener
- testExecutionSkippedByUser() - Method in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- testExecutionSkippedByUser() - Method in class org.apache.maven.surefire.api.booter.ForkingRunListener
- testExecutionSkippedByUser() - Method in interface org.apache.maven.surefire.api.report.RunListener
-
Event fired skipping an execution of remaining test-set in other fork(s); or does nothing if no forks.
- testExecutionSkippedByUser() - Method in class org.apache.maven.surefire.common.junit4.JUnit4RunListener
-
Delegates to
RunListener.testExecutionSkippedByUser()
. - testExecutionSkippedByUser() - Method in class org.apache.maven.surefire.junit.JUnit3Reporter
- testExecutionSkippedByUser() - Method in class org.apache.maven.surefire.junitcore.ConcurrentRunListener
-
Deprecated.
- testFailed(ReportEntry) - Method in class org.apache.maven.plugin.surefire.report.NullStatisticsReporter
- testFailed(ReportEntry) - Method in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- testFailed(ReportEntry) - Method in class org.apache.maven.plugin.surefire.runorder.StatisticsReporter
- testFailed(ReportEntry) - Method in class org.apache.maven.surefire.api.booter.ForkingRunListener
- testFailed(ReportEntry) - Method in interface org.apache.maven.surefire.api.report.RunListener
-
Event fired when a test ended with a failure (anticipated problem)
- testFailed(ReportEntry) - Method in class org.apache.maven.surefire.junit.JUnit3Reporter
- testFailed(ReportEntry) - Method in class org.apache.maven.surefire.junitcore.ConcurrentRunListener
-
Deprecated.
- testFailed(ReportEntry, boolean) - Method in interface org.apache.maven.surefire.api.booter.MasterProcessChannelEncoder
-
The test has failed.
- testFailed(ReportEntry, boolean) - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- TestFailedEvent - Class in org.apache.maven.surefire.api.event
-
The event for the failed test.
- TestFailedEvent(ReportEntry) - Constructor for class org.apache.maven.surefire.api.event.TestFailedEvent
- TestFailedListener() - Constructor for class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.TestFailedListener
- testFailure - Variable in class org.apache.maven.surefire.junitcore.TestMethod
-
Deprecated.
- testFailure(WrappedReportEntry) - Method in class org.apache.maven.plugin.surefire.report.TestSetStats
- testFailure(ReportEntry) - Method in class org.apache.maven.surefire.junitcore.TestMethod
-
Deprecated.
- testFailure(Failure) - Method in class org.apache.maven.surefire.common.junit4.JUnit4RunListener
-
Called when a specific test has failed.
- testFailure(Failure) - Method in class org.apache.maven.surefire.common.junit4.JUnitTestFailureListener
- testFailure(Failure) - Method in class org.apache.maven.surefire.junitcore.NonConcurrentRunListener
-
Deprecated.
- testFailureIgnore - Variable in class org.apache.maven.plugin.failsafe.VerifyMojo
-
Set this to true to ignore a failure during testing.
- testFailureIgnore - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
Set this to "true" to ignore a failure during testing.
- TestFilter<C,
M> - Interface in org.apache.maven.surefire.api.testset -
Generic interface of test filter.
- testFinished() - Method in class org.apache.maven.surefire.junitcore.TestMethod
-
Deprecated.
- testFinished(Description) - Method in class org.apache.maven.surefire.common.junit4.JUnit4RunListener
-
Called after a specific test has finished.
- testFinished(Description) - Method in class org.apache.maven.surefire.junitcore.NonConcurrentRunListener
-
Deprecated.
- testIdMapping - Variable in class org.apache.maven.surefire.report.ClassMethodIndexer
- testIgnored - Variable in class org.apache.maven.surefire.junitcore.TestMethod
-
Deprecated.
- testIgnored(ReportEntry) - Method in class org.apache.maven.surefire.junitcore.TestMethod
-
Deprecated.
- testIgnored(Description) - Method in class org.apache.maven.surefire.common.junit4.JUnit4RunListener
-
Called when a specific test has been skipped (for whatever reason).
- testIgnored(Description) - Method in class org.apache.maven.surefire.junitcore.NonConcurrentRunListener
-
Deprecated.
- testInterface - Variable in class org.apache.maven.surefire.common.junit3.JUnit3Reflector
- testInterfaceRunMethod - Variable in class org.apache.maven.surefire.common.junit3.JUnit3Reflector
- TestLessInputStream - Class in org.apache.maven.plugin.surefire.booterclient.lazytestprovider
-
Dispatches commands without tests.
- TestLessInputStream(TestLessInputStream.TestLessInputStreamBuilder) - Constructor for class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream
- TestLessInputStream.TestLessInputStreamBuilder - Class in org.apache.maven.plugin.surefire.booterclient.lazytestprovider
-
Builds
streams
, registers cachable commands and provides accessible API to dispatch immediate commands to all atomically alive streams. - TestLessInputStream.TestLessInputStreamBuilder.CachableCommands - Class in org.apache.maven.plugin.surefire.booterclient.lazytestprovider
-
Event is persisted.
- TestLessInputStream.TestLessInputStreamBuilder.CIt - Class in org.apache.maven.plugin.surefire.booterclient.lazytestprovider
- TestLessInputStream.TestLessInputStreamBuilder.ImmediateCommands - Class in org.apache.maven.plugin.surefire.booterclient.lazytestprovider
-
Event is called just now for all alive streams and command is not persisted.
- TestLessInputStream.TestLessInputStreamBuilder.Node - Class in org.apache.maven.plugin.surefire.booterclient.lazytestprovider
- TestLessInputStreamBuilder() - Constructor for class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestLessInputStream.TestLessInputStreamBuilder
- TestListenerInvocationHandler - Class in org.apache.maven.surefire.junit
-
Invocation Handler for TestListener proxies to delegate to our
RunListener
- TestListenerInvocationHandler(JUnit3Reporter) - Constructor for class org.apache.maven.surefire.junit.TestListenerInvocationHandler
- TestListenerInvocationHandler.FailedTest - Class in org.apache.maven.surefire.junit
- testListResolver - Variable in class org.apache.maven.surefire.booter.SurefireReflector
- testListResolver - Variable in class org.apache.maven.surefire.junitplatform.TestMethodFilter
- testListResolver - Static variable in class org.apache.maven.surefire.testng.utils.MethodSelector
- TestListResolver - Class in org.apache.maven.surefire.api.testset
-
Resolved multi pattern filter e.g.
- TestListResolver(boolean, boolean, Set<ResolvedTest>, Set<ResolvedTest>) - Constructor for class org.apache.maven.surefire.api.testset.TestListResolver
-
Used only in method filter.
- TestListResolver(String) - Constructor for class org.apache.maven.surefire.api.testset.TestListResolver
- TestListResolver(Collection<String>) - Constructor for class org.apache.maven.surefire.api.testset.TestListResolver
- TestListResolver(Collection<String>, Collection<String>) - Constructor for class org.apache.maven.surefire.api.testset.TestListResolver
- testLocalMapping - Variable in class org.apache.maven.surefire.report.ClassMethodIndexer
- TestMetadata() - Constructor for class org.apache.maven.surefire.testng.TestNGExecutor.TestMetadata
- testMethod - Variable in class org.apache.maven.surefire.api.report.LegacyPojoStackTraceWriter
- testMethod - Variable in class org.apache.maven.surefire.report.PojoStackTraceWriter
- TestMethod - Class in org.apache.maven.surefire.junitcore
-
Deprecated.
- TestMethod(ReportEntry, TestSet) - Constructor for class org.apache.maven.surefire.junitcore.TestMethod
-
Deprecated.
- TestMethodFilter - Class in org.apache.maven.surefire.junitplatform
- TestMethodFilter(TestListResolver) - Constructor for class org.apache.maven.surefire.junitplatform.TestMethodFilter
- testMethodName - Variable in class org.apache.maven.surefire.report.SmartStackTraceParser
- testMethods - Variable in class org.apache.maven.surefire.junit.PojoTestSetExecutor.DiscoveredTestMethods
- testMethods - Variable in class org.apache.maven.surefire.junitcore.TestSet
-
Deprecated.
- testMethodStats - Variable in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- TestMethodStats - Class in org.apache.maven.plugin.surefire.report
-
Maintains per-thread test result state for a single test method.
- TestMethodStats(String, ReportEntryType, StackTraceWriter) - Constructor for class org.apache.maven.plugin.surefire.report.TestMethodStats
- testModuleDescriptor - Variable in class org.apache.maven.surefire.providerapi.ProviderRequirements
- testName - Variable in class org.apache.maven.surefire.testng.TestNGExecutor.TestMetadata
- testName(ITestResult) - Static method in class org.apache.maven.surefire.testng.TestNGReporter
-
Acquire a better representation of the test name that includes parameters and the invocation count, if there are any parameters
- testNameToTest - Variable in class org.apache.maven.surefire.testng.TestNGExecutor.SuiteAndNamedTests
- TESTNG_EXCLUDEDGROUPS_PROP - Static variable in class org.apache.maven.surefire.api.booter.ProviderParameterNames
- TESTNG_GROUPS_PROP - Static variable in class org.apache.maven.surefire.api.booter.ProviderParameterNames
- TestNG4751Configurator - Class in org.apache.maven.surefire.testng.conf
-
TestNG 4.7 and 5.1 configurator.
- TestNG4751Configurator() - Constructor for class org.apache.maven.surefire.testng.conf.TestNG4751Configurator
- TestNG510Configurator - Class in org.apache.maven.surefire.testng.conf
-
TestNG 5.10 configurator.
- TestNG510Configurator() - Constructor for class org.apache.maven.surefire.testng.conf.TestNG510Configurator
- TestNG513Configurator - Class in org.apache.maven.surefire.testng.conf
-
TestNG 5.13 configurator.
- TestNG513Configurator() - Constructor for class org.apache.maven.surefire.testng.conf.TestNG513Configurator
- TestNG5141Configurator - Class in org.apache.maven.surefire.testng.conf
-
TestNG 5.14.1 configurator.
- TestNG5141Configurator() - Constructor for class org.apache.maven.surefire.testng.conf.TestNG5141Configurator
- TestNG5143Configurator - Class in org.apache.maven.surefire.testng.conf
-
TestNG 5.14.3 configurator.
- TestNG5143Configurator() - Constructor for class org.apache.maven.surefire.testng.conf.TestNG5143Configurator
- TestNG52Configurator - Class in org.apache.maven.surefire.testng.conf
-
TestNG 5.2 configurator.
- TestNG52Configurator() - Constructor for class org.apache.maven.surefire.testng.conf.TestNG52Configurator
- TestNG60Configurator - Class in org.apache.maven.surefire.testng.conf
-
TestNG 6.0 configurator.
- TestNG60Configurator() - Constructor for class org.apache.maven.surefire.testng.conf.TestNG60Configurator
- TestNG740Configurator - Class in org.apache.maven.surefire.testng.conf
-
TestNG 7.4.0 configurator.
- TestNG740Configurator() - Constructor for class org.apache.maven.surefire.testng.conf.TestNG740Configurator
- testNgArtifact - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo.TestNgProviderInfo
- testNGArtifactName - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Allows you to specify the name of the TestNG artifact.
- TestNGDirectoryTestSuite - Class in org.apache.maven.surefire.testng
-
Test suite for TestNG based on a directory of Java test classes.
- TestNGDirectoryTestSuite(String, Map<String, String>, File, TestListResolver, List<CommandLineOption>, int) - Constructor for class org.apache.maven.surefire.testng.TestNGDirectoryTestSuite
- TestNGExecutor - Class in org.apache.maven.surefire.testng
-
Contains utility methods for executing TestNG.
- TestNGExecutor() - Constructor for class org.apache.maven.surefire.testng.TestNGExecutor
- TestNGExecutor.SuiteAndNamedTests - Class in org.apache.maven.surefire.testng
- TestNGExecutor.TestMetadata - Class in org.apache.maven.surefire.testng
- TestNGMapConfigurator - Class in org.apache.maven.surefire.testng.conf
-
TestNG configurator for 5.3+ versions.
- TestNGMapConfigurator() - Constructor for class org.apache.maven.surefire.testng.conf.TestNGMapConfigurator
- TestNGProvider - Class in org.apache.maven.surefire.testng
- TestNGProvider(ProviderParameters) - Constructor for class org.apache.maven.surefire.testng.TestNGProvider
- TestNgProviderInfo(Artifact) - Constructor for class org.apache.maven.plugin.surefire.AbstractSurefireMojo.TestNgProviderInfo
- TestNGReporter - Class in org.apache.maven.surefire.testng
-
Listens for and provides and adaptor layer so that TestNG tests can report their status to the current
RunListener
. - TestNGReporter(TestReportListener<TestOutputReportEntry>) - Constructor for class org.apache.maven.surefire.testng.TestNGReporter
-
Constructs a new instance that will listen to test updates from a
TestNG
class instance. - TestNGXmlTestSuite - Class in org.apache.maven.surefire.testng
-
Handles suite xml file definitions for TestNG.
- TestNGXmlTestSuite(List<File>, String, Map<String, String>, File, int) - Constructor for class org.apache.maven.surefire.testng.TestNGXmlTestSuite
-
Creates a testng testset to be configured by the specified xml file(s).
- testOutput(TestOutputReportEntry) - Method in interface org.apache.maven.surefire.api.booter.MasterProcessChannelEncoder
-
Test output, a line or characters.
- testOutput(TestOutputReportEntry) - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- testOutputReceiver - Variable in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- TestOutputReceiver<T extends OutputReportEntry> - Interface in org.apache.maven.surefire.api.report
-
A receiver of stdout/sterr output from running tests.
- TestOutputReportEntry - Class in org.apache.maven.surefire.api.report
-
This report entry should be used in
TestOutputReceiver.writeTestOutput(OutputReportEntry)
. - TestOutputReportEntry(String, boolean, boolean) - Constructor for class org.apache.maven.surefire.api.report.TestOutputReportEntry
-
Wraps the output from the running test-case.
- TestOutputReportEntry(String, boolean, boolean, RunMode, Long) - Constructor for class org.apache.maven.surefire.api.report.TestOutputReportEntry
-
Wraps the output from the running test-case.
- TestOutputReportEntry(OutputReportEntry, RunMode, Long) - Constructor for class org.apache.maven.surefire.api.report.TestOutputReportEntry
- testPlan - Variable in class org.apache.maven.surefire.junitplatform.RunListenerAdapter
- testPlanExecutionFinished(TestPlan) - Method in class org.apache.maven.surefire.junitplatform.RunListenerAdapter
- testPlanExecutionStarted(TestPlan) - Method in class org.apache.maven.surefire.junitplatform.RunListenerAdapter
- TestPlanScannerFilter - Class in org.apache.maven.surefire.junitplatform
- TestPlanScannerFilter(Launcher, Filter<?>[]) - Constructor for class org.apache.maven.surefire.junitplatform.TestPlanScannerFilter
- testProvidingInputStream - Variable in class org.apache.maven.plugin.surefire.booterclient.ForkStarter.CloseableCloser
- TestProvidingInputStream - Class in org.apache.maven.plugin.surefire.booterclient.lazytestprovider
-
An
InputStream
that, when read, provides test class names out of a queue. - TestProvidingInputStream(Queue<String>) - Constructor for class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestProvidingInputStream
-
C'tor
- TestReportListener<T extends OutputReportEntry> - Interface in org.apache.maven.surefire.api.report
-
This architecture has two sides (forked JVM, plugin JVM) implementing the same interface
TestReportListener
: - testRequest - Variable in class org.apache.maven.surefire.api.booter.BaseProviderFactory
- testRequest - Variable in class org.apache.maven.surefire.booter.SurefireReflector
- testRequest - Variable in class org.apache.maven.surefire.testng.TestNGProvider
- TestRequest - Class in org.apache.maven.surefire.api.testset
-
Information about the requested test.
- TestRequest(List, File, TestListResolver) - Constructor for class org.apache.maven.surefire.api.testset.TestRequest
- TestRequest(List, File, TestListResolver, int) - Constructor for class org.apache.maven.surefire.api.testset.TestRequest
- testResolver - Variable in class org.apache.maven.surefire.junit4.JUnit4Provider
- testResolver - Variable in class org.apache.maven.surefire.junitcore.JUnitCoreProvider
- TestResolverFilter - Class in org.apache.maven.surefire.junit4
-
Method filter used in
JUnit4Provider
. - TestResolverFilter(TestListResolver) - Constructor for class org.apache.maven.surefire.junit4.TestResolverFilter
- testResultClass - Variable in class org.apache.maven.surefire.common.junit3.JUnit3Reflector
- TestResultType(String) - Constructor for enum class org.apache.maven.plugin.surefire.report.DefaultReporterFactory.TestResultType
- testRunFinished(Result) - Method in class org.apache.maven.surefire.junitcore.JUnitCoreRunListener
- testRunFinished(Result) - Method in class org.apache.maven.surefire.junitcore.NonConcurrentRunListener
-
Deprecated.
- testRunId - Variable in class org.apache.maven.surefire.api.event.AbstractStandardStreamEvent
- testRunId - Variable in class org.apache.maven.surefire.api.event.SystemPropertyEvent
- testRunId - Variable in class org.apache.maven.surefire.api.report.SimpleReportEntry
- testRunId - Variable in class org.apache.maven.surefire.api.report.TestOutputReportEntry
- testRunStarted(Description) - Method in class org.apache.maven.surefire.junitcore.JUnitCoreRunListener
-
Called right before any tests from a specific class are run.
- testRunStarted(Description) - Method in class org.apache.maven.surefire.junitcore.NonConcurrentRunListener
-
Deprecated.
- TestRuntimeComparator() - Constructor for class org.apache.maven.surefire.api.runorder.RunEntryStatisticsMap.TestRuntimeComparator
- TESTS - Static variable in class org.apache.maven.plugin.surefire.report.TestSetStats
- TESTS_RUN - Static variable in class org.apache.maven.plugin.surefire.report.TestSetStats
- testsClassLoader - Variable in class org.apache.maven.surefire.booter.ProviderFactory.ProviderProxy
- testSet - Variable in class org.apache.maven.surefire.booter.ForkedBooter
- testSet - Variable in class org.apache.maven.surefire.junitcore.TestMethod
-
Deprecated.
- TestSet - Class in org.apache.maven.surefire.junitcore
-
Deprecated.
- TestSet(String, RunMode, ClassMethodIndexer) - Constructor for class org.apache.maven.surefire.junitcore.TestSet
-
Deprecated.
- testSetCompleted() - Method in class org.apache.maven.plugin.surefire.report.NullStatisticsReporter
- testSetCompleted() - Method in class org.apache.maven.plugin.surefire.runorder.StatisticsReporter
- testSetCompleted(WrappedReportEntry, TestSetStats) - Method in class org.apache.maven.plugin.surefire.report.NullStatelessXmlReporter
- testSetCompleted(WrappedReportEntry, TestSetStats) - Method in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- testSetCompleted(WrappedReportEntry, TestSetStats, List<String>) - Method in class org.apache.maven.plugin.surefire.report.ConsoleReporter
- testSetCompleted(WrappedReportEntry, TestSetStats, List<String>) - Method in class org.apache.maven.plugin.surefire.report.FileReporter
- testSetCompleted(WrappedReportEntry, TestSetStats, List<String>) - Method in class org.apache.maven.plugin.surefire.report.NullConsoleReporter
- testSetCompleted(WrappedReportEntry, TestSetStats, List<String>) - Method in class org.apache.maven.plugin.surefire.report.NullFileReporter
- testSetCompleted(TestSetReportEntry) - Method in class org.apache.maven.plugin.surefire.report.ConsoleOutputFileReporter
- testSetCompleted(TestSetReportEntry) - Method in class org.apache.maven.plugin.surefire.report.DirectConsoleOutput
- testSetCompleted(TestSetReportEntry) - Method in class org.apache.maven.plugin.surefire.report.NullConsoleOutputReceiver
- testSetCompleted(TestSetReportEntry) - Method in interface org.apache.maven.plugin.surefire.report.TestcycleConsoleOutputReceiver
- testSetCompleted(TestSetReportEntry) - Method in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- testSetCompleted(TestSetReportEntry) - Method in class org.apache.maven.surefire.api.booter.ForkingRunListener
- testSetCompleted(TestSetReportEntry) - Method in interface org.apache.maven.surefire.api.report.RunListener
-
Indicates end of a given test-set
- testSetCompleted(TestSetReportEntry) - Method in interface org.apache.maven.surefire.extensions.ConsoleOutputReportEventListener
- testSetCompleted(TestSetReportEntry) - Method in class org.apache.maven.surefire.junit.JUnit3Reporter
- testSetCompleted(TestSetReportEntry) - Method in class org.apache.maven.surefire.junitcore.ConcurrentRunListener
-
Deprecated.
- testSetCompleted(TestSetReportEntry, boolean) - Method in interface org.apache.maven.surefire.api.booter.MasterProcessChannelEncoder
-
The test set has finished.
- testSetCompleted(TestSetReportEntry, boolean) - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- testSetCompleted(R, S) - Method in interface org.apache.maven.surefire.extensions.StatelessReportEventListener
-
The callback is called after the test class has been completed and the state of report is final.
- testSetCompleted(R, S, List<String>) - Method in class org.apache.maven.surefire.extensions.StatelessTestsetInfoConsoleReportEventListener
- testSetCompleted(R, S, List<String>) - Method in class org.apache.maven.surefire.extensions.StatelessTestsetInfoFileReportEventListener
- TestsetCompletedEvent - Class in org.apache.maven.surefire.api.event
-
The event for completed testset.
- TestsetCompletedEvent(TestSetReportEntry) - Constructor for class org.apache.maven.surefire.api.event.TestsetCompletedEvent
- TestSetCompletedListener() - Constructor for class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.TestSetCompletedListener
- TestSetFailedException - Exception in org.apache.maven.surefire.api.testset
-
Exception that indicates a test failed.
- TestSetFailedException(String) - Constructor for exception org.apache.maven.surefire.api.testset.TestSetFailedException
-
Creates
TestSetFailedException
with a detail message. - TestSetFailedException(String, Throwable) - Constructor for exception org.apache.maven.surefire.api.testset.TestSetFailedException
-
Creates
TestSetFailedException
with the specified detail message and cause. - TestSetFailedException(Throwable) - Constructor for exception org.apache.maven.surefire.api.testset.TestSetFailedException
-
Creates
TestSetFailedException
with the specified cause. - testSetFinished() - Method in class org.apache.maven.plugin.surefire.booterclient.lazytestprovider.TestProvidingInputStream
-
For testing purposes.
- TestSetReportEntry - Interface in org.apache.maven.surefire.api.report
-
Describes test-set when started and finished.
- testsetReporter - Variable in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- testSetReporter - Variable in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
- TestSetRunListener - Class in org.apache.maven.plugin.surefire.report
-
Reports data for a single test set.
- TestSetRunListener(StatelessTestsetInfoConsoleReportEventListener<WrappedReportEntry, TestSetStats>, StatelessTestsetInfoFileReportEventListener<WrappedReportEntry, TestSetStats>, StatelessReportEventListener<WrappedReportEntry, TestSetStats>, ConsoleOutputReportEventListener, StatisticsReporter, boolean, boolean, boolean, Object) - Constructor for class org.apache.maven.plugin.surefire.report.TestSetRunListener
- testSetStart() - Method in class org.apache.maven.plugin.surefire.report.TestSetStats
- testSetStartAt - Variable in class org.apache.maven.plugin.surefire.report.TestSetStats
- testSetStartedAt - Variable in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
-
testSetStartedAt is set to non-zero after received
MasterProcessChannelEncoder.testSetStarting(TestSetReportEntry, boolean)
. - testSetStarting(TestSetReportEntry) - Method in class org.apache.maven.plugin.surefire.report.ConsoleOutputFileReporter
- testSetStarting(TestSetReportEntry) - Method in class org.apache.maven.plugin.surefire.report.ConsoleReporter
- testSetStarting(TestSetReportEntry) - Method in class org.apache.maven.plugin.surefire.report.DirectConsoleOutput
- testSetStarting(TestSetReportEntry) - Method in class org.apache.maven.plugin.surefire.report.NullConsoleOutputReceiver
- testSetStarting(TestSetReportEntry) - Method in class org.apache.maven.plugin.surefire.report.NullConsoleReporter
- testSetStarting(TestSetReportEntry) - Method in interface org.apache.maven.plugin.surefire.report.TestcycleConsoleOutputReceiver
- testSetStarting(TestSetReportEntry) - Method in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- testSetStarting(TestSetReportEntry) - Method in class org.apache.maven.surefire.api.booter.ForkingRunListener
- testSetStarting(TestSetReportEntry) - Method in interface org.apache.maven.surefire.api.report.RunListener
-
Indicates the start of a given test-set
- testSetStarting(TestSetReportEntry) - Method in interface org.apache.maven.surefire.extensions.ConsoleOutputReportEventListener
- testSetStarting(TestSetReportEntry) - Method in class org.apache.maven.surefire.extensions.StatelessTestsetInfoConsoleReportEventListener
- testSetStarting(TestSetReportEntry) - Method in class org.apache.maven.surefire.junit.JUnit3Reporter
- testSetStarting(TestSetReportEntry) - Method in class org.apache.maven.surefire.junitcore.ConcurrentRunListener
-
Deprecated.
- testSetStarting(TestSetReportEntry, boolean) - Method in interface org.apache.maven.surefire.api.booter.MasterProcessChannelEncoder
-
The test set has started.
- testSetStarting(TestSetReportEntry, boolean) - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- TestsetStartingEvent - Class in org.apache.maven.surefire.api.event
-
The event for started testset.
- TestsetStartingEvent(TestSetReportEntry) - Constructor for class org.apache.maven.surefire.api.event.TestsetStartingEvent
- TestSetStartingListener() - Constructor for class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.TestSetStartingListener
- TestSetStats - Class in org.apache.maven.plugin.surefire.report
-
Maintains per-thread test result state.
- TestSetStats(boolean, boolean) - Constructor for class org.apache.maven.plugin.surefire.report.TestSetStats
- testsInProgress - Variable in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
- testsInProgress() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
- testSkipped(WrappedReportEntry) - Method in class org.apache.maven.plugin.surefire.report.TestSetStats
- testSkipped(ReportEntry) - Method in class org.apache.maven.plugin.surefire.report.NullStatisticsReporter
- testSkipped(ReportEntry) - Method in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- testSkipped(ReportEntry) - Method in class org.apache.maven.plugin.surefire.runorder.StatisticsReporter
- testSkipped(ReportEntry) - Method in class org.apache.maven.surefire.api.booter.ForkingRunListener
- testSkipped(ReportEntry) - Method in interface org.apache.maven.surefire.api.report.RunListener
-
Event fired when a test is skipped
- testSkipped(ReportEntry) - Method in class org.apache.maven.surefire.junit.JUnit3Reporter
- testSkipped(ReportEntry) - Method in class org.apache.maven.surefire.junitcore.ConcurrentRunListener
-
Deprecated.
- testSkipped(ReportEntry, boolean) - Method in interface org.apache.maven.surefire.api.booter.MasterProcessChannelEncoder
-
The test is skipped.
- testSkipped(ReportEntry, boolean) - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- TestSkippedEvent - Class in org.apache.maven.surefire.api.event
-
The event for the skipped test.
- TestSkippedEvent(ReportEntry) - Constructor for class org.apache.maven.surefire.api.event.TestSkippedEvent
- TestSkippedListener() - Constructor for class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.TestSkippedListener
- testSourceDirectory - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
The test source directory containing test class sources.
- testSourceDirectory - Variable in class org.apache.maven.surefire.api.testset.TestRequest
- testSourceDirectory - Variable in class org.apache.maven.surefire.testng.TestNGDirectoryTestSuite
- testSourceDirectory - Variable in class org.apache.maven.surefire.testng.TestNGXmlTestSuite
- testsSuiteConstructor - Variable in class org.apache.maven.surefire.common.junit3.JUnit3Reflector
- testStart() - Method in class org.apache.maven.plugin.surefire.report.TestSetStats
- testStartAt - Variable in class org.apache.maven.plugin.surefire.report.TestSetStats
- testStarted(Description) - Method in class org.apache.maven.surefire.common.junit4.JUnit4RunListener
-
Called when a specific test has started.
- testStarted(Description) - Method in class org.apache.maven.surefire.junitcore.NonConcurrentRunListener
-
Deprecated.
- testStarting(ReportEntry) - Method in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- testStarting(ReportEntry) - Method in class org.apache.maven.surefire.api.booter.ForkingRunListener
- testStarting(ReportEntry) - Method in interface org.apache.maven.surefire.api.report.RunListener
-
Event fired when a test is about to start
- testStarting(ReportEntry) - Method in class org.apache.maven.surefire.junit.JUnit3Reporter
- testStarting(ReportEntry) - Method in class org.apache.maven.surefire.junitcore.ConcurrentRunListener
-
Deprecated.
- testStarting(ReportEntry, boolean) - Method in interface org.apache.maven.surefire.api.booter.MasterProcessChannelEncoder
-
The test has started.
- testStarting(ReportEntry, boolean) - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- TestStartingEvent - Class in org.apache.maven.surefire.api.event
-
The event for started test.
- TestStartingEvent(ReportEntry) - Constructor for class org.apache.maven.surefire.api.event.TestStartingEvent
- TestStartingListener() - Constructor for class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.TestStartingListener
- testStartTime - Variable in class org.apache.maven.surefire.junitplatform.RunListenerAdapter
- testStdErr - Variable in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- testStdOut - Variable in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- testsToRun - Variable in class org.apache.maven.surefire.junit4.JUnit4Provider
- testsToRun - Variable in class org.apache.maven.surefire.junitcore.JUnitCoreProvider
- TestsToRun - Class in org.apache.maven.surefire.api.util
-
Contains all the tests that have been found according to specified include/exclude specification for a given surefire run.
- TestsToRun(Set<Class<?>>) - Constructor for class org.apache.maven.surefire.api.util.TestsToRun
-
Constructor
- TestsToRun.ClassesIterator - Class in org.apache.maven.surefire.api.util
- testSucceeded(WrappedReportEntry) - Method in class org.apache.maven.plugin.surefire.report.TestSetStats
- testSucceeded(ReportEntry) - Method in class org.apache.maven.plugin.surefire.report.NullStatisticsReporter
- testSucceeded(ReportEntry) - Method in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- testSucceeded(ReportEntry) - Method in class org.apache.maven.plugin.surefire.runorder.StatisticsReporter
- testSucceeded(ReportEntry) - Method in class org.apache.maven.surefire.api.booter.ForkingRunListener
- testSucceeded(ReportEntry) - Method in interface org.apache.maven.surefire.api.report.RunListener
-
Event fired when a test ended successfully
- testSucceeded(ReportEntry) - Method in class org.apache.maven.surefire.junit.JUnit3Reporter
- testSucceeded(ReportEntry) - Method in class org.apache.maven.surefire.junitcore.ConcurrentRunListener
-
Deprecated.
- testSucceeded(ReportEntry, boolean) - Method in interface org.apache.maven.surefire.api.booter.MasterProcessChannelEncoder
-
The test has succeeded.
- testSucceeded(ReportEntry, boolean) - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- TestSucceededEvent - Class in org.apache.maven.surefire.api.event
-
The event for succeeded test.
- TestSucceededEvent(ReportEntry) - Constructor for class org.apache.maven.surefire.api.event.TestSucceededEvent
- TestSucceededListener() - Constructor for class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.TestSucceededListener
- TestSuite - Class in org.apache.maven.surefire.testng
-
Abstract class which implements common functions.
- TestSuite() - Constructor for class org.apache.maven.surefire.testng.TestSuite
- testSuiteDefinition - Variable in class org.apache.maven.surefire.booter.ProviderConfiguration
- testThatFailed - Variable in class org.apache.maven.surefire.junit.TestListenerInvocationHandler.FailedTest
- testVmSystemProperties - Variable in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
- THREAD_NUMBER_PLACEHOLDER - Static variable in class org.apache.maven.plugin.surefire.SurefireHelper
-
The placeholder that is replaced by the executing thread's running number.
- THREAD_POOL - Static variable in class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel
- threadCount - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
(TestNG/JUnit 4.7 provider) The attribute thread-count allows you to specify how many threads should be allocated for this execution.
- threadCount - Variable in class org.apache.maven.surefire.api.util.DefaultRunOrderCalculator
- threadCount - Variable in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- THREADCOUNT_KEY - Static variable in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- THREADCOUNT_PROP - Static variable in class org.apache.maven.surefire.api.booter.ProviderParameterNames
- threadCountClasses - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
(JUnit 4.7 provider) This attribute allows you to specify the concurrency in test classes, i.e.: number of concurrent classes if
threadCount
is 0 or unspecified limited classes concurrency ifuseUnlimitedThreads
is set to true ifthreadCount
and certain thread-count parameters are > 0 forparallel
, the concurrency is computed from ratio. - threadCountClasses - Variable in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- threadCountClasses(JUnitCoreParameters) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerUtil
- THREADCOUNTCLASSES_KEY - Static variable in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- THREADCOUNTCLASSES_PROP - Static variable in class org.apache.maven.surefire.api.booter.ProviderParameterNames
- threadCountMethods - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
(JUnit 4.7 provider) This attribute allows you to specify the concurrency in test methods, i.e.: number of concurrent methods if
threadCount
is 0 or unspecified limited concurrency of methods ifuseUnlimitedThreads
is set to true ifthreadCount
and certain thread-count parameters are > 0 forparallel
, the concurrency is computed from ratio. - threadCountMethods - Variable in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- threadCountMethods(JUnitCoreParameters) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerUtil
- THREADCOUNTMETHODS_KEY - Static variable in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- THREADCOUNTMETHODS_PROP - Static variable in class org.apache.maven.surefire.api.booter.ProviderParameterNames
- threadCountSuites - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
(JUnit 4.7 provider) This attribute allows you to specify the concurrency in test suites, i.e.: number of concurrent suites if
threadCount
is 0 or unspecified limited suites concurrency ifuseUnlimitedThreads
is set to true ifthreadCount
and certain thread-count parameters are > 0 forparallel
, the concurrency is computed from ratio. - threadCountSuites - Variable in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- threadCountSuites(JUnitCoreParameters) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerUtil
- THREADCOUNTSUITES_KEY - Static variable in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- THREADCOUNTSUITES_PROP - Static variable in class org.apache.maven.surefire.api.booter.ProviderParameterNames
- ThreadedExecutionScheduler - Class in org.apache.maven.surefire.api.runorder
- ThreadedExecutionScheduler(int) - Constructor for class org.apache.maven.surefire.api.runorder.ThreadedExecutionScheduler
- ThreadedStreamConsumer - Class in org.apache.maven.plugin.surefire.booterclient.output
-
Knows how to reconstruct *all* the state transmitted over Channel by the forked process.
- ThreadedStreamConsumer(EventHandler<Event>) - Constructor for class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer
- ThreadedStreamConsumer.FinalEvent - Class in org.apache.maven.plugin.surefire.booterclient.output
- ThreadedStreamConsumer.Pumper - Class in org.apache.maven.plugin.surefire.booterclient.output
- ThreadedStreamConsumer.QueueSynchronizer<T> - Class in org.apache.maven.plugin.surefire.booterclient.output
-
This synchronization helper mostly avoids the locks.
- ThreadedStreamConsumer.QueueSynchronizer.SyncT1 - Class in org.apache.maven.plugin.surefire.booterclient.output
- ThreadedStreamConsumer.QueueSynchronizer.SyncT2 - Class in org.apache.maven.plugin.surefire.booterclient.output
- threadNumber - Variable in class org.apache.maven.surefire.api.util.internal.DaemonThreadFactory
- threadOnWhichTestFailed - Variable in class org.apache.maven.surefire.junit.TestListenerInvocationHandler.FailedTest
- threadPool - Variable in class org.apache.maven.surefire.junitcore.pc.AbstractThreadPoolStrategy
- ThreadResourcesBalancer - Class in org.apache.maven.surefire.junitcore.pc
- ThreadResourcesBalancer(int) - Constructor for class org.apache.maven.surefire.junitcore.pc.ThreadResourcesBalancer
-
fair
set to false. - ThreadResourcesBalancer(int, boolean) - Constructor for class org.apache.maven.surefire.junitcore.pc.ThreadResourcesBalancer
- throwable - Variable in class org.apache.maven.surefire.report.SmartStackTraceParser
- throwErrors() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.Pumper
- throwException(SurefireReportParameters, RunResult, Exception) - Static method in class org.apache.maven.plugin.surefire.SurefireHelper
- throwSanityError(IllegalArgumentException) - Static method in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- time - Variable in class org.apache.maven.surefire.booter.ProcessInfo
- timeout - Variable in class org.apache.maven.surefire.api.suite.RunResult
- timeout(RunResult) - Static method in class org.apache.maven.surefire.api.suite.RunResult
- TIMEOUT - Enum constant in enum class org.apache.maven.surefire.junitcore.pc.ExecutionStatus
- TIMEOUT_CHECK_PERIOD_MILLIS - Static variable in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- timeoutCheckScheduler - Variable in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- timeoutForcedNanos - Variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputer
- timeoutNanos - Variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputer
- toAbsoluteCanonical(File) - Static method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- toAbsoluteUri(Path) - Static method in class org.apache.maven.plugin.surefire.booterclient.JarManifestForkConfiguration
- toClass(String) - Static method in class org.apache.maven.surefire.report.SmartStackTraceParser
- toClassFileName(Class<?>) - Static method in class org.apache.maven.surefire.api.testset.TestListResolver
- toClassFileName(String) - Static method in class org.apache.maven.surefire.api.testset.TestListResolver
- toClassMethod(Description) - Static method in class org.apache.maven.surefire.common.junit4.JUnit4ProviderUtil
-
Java Patterns of regex is slower than cutting a substring.
- toClassMethodName(TestIdentifier) - Method in class org.apache.maven.surefire.junitplatform.RunListenerAdapter
-
[0] class name - used in stacktrace parser [1] class display name [2] method signature - used in stacktrace parser [3] method display name
- toClasspath() - Method in class org.apache.maven.plugin.surefire.TestClassPath
- toClasspathElementUri(Path, Path, File, boolean) - Static method in class org.apache.maven.plugin.surefire.booterclient.JarManifestForkConfiguration
- toCompleteClasspath(StartupConfiguration) - Method in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- toEnum(String) - Static method in enum class org.apache.maven.surefire.booter.ProcessCheckerType
-
Converts string (ping, native, all) to
ProcessCheckerType
. - toFile(String, String) - Method in class org.apache.maven.plugin.surefire.util.FileScanner
- toImmutable(Map<K, V>) - Static method in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
-
Immutable map.
- toJavaPackage(String...) - Static method in class org.apache.maven.plugin.surefire.util.FileScanner
- toJdkHomeFromJre() - Static method in class org.apache.maven.surefire.booter.SystemUtils
-
If system property
java.home
is/jdk
(since jdk9) or/jdk/jre
(prior to jdk9) then the absolute path to JDK home is returned/jdk
. - toJdkHomeFromJre(String) - Static method in class org.apache.maven.surefire.booter.SystemUtils
-
If
jreHome
is/jdk
(since jdk9) or/jdk/jre
(prior to jdk9) then the absolute path to JDK home is returned/jdk
. - toJdkHomeFromJvmExec(String) - Static method in class org.apache.maven.surefire.booter.SystemUtils
-
If
jvmExecutable
is/jdk/bin/java
(since jdk9) or/jdk/jre/bin/java
(prior to jdk9) then the absolute path to JDK home is returned/jdk
. - toJdkVersionFromReleaseFile(File) - Static method in class org.apache.maven.surefire.booter.SystemUtils
- toMessage(Function<Throwable, String>) - Method in exception org.apache.maven.plugin.surefire.booterclient.output.MultipleFailureException
- toMessage(MT, AbstractStreamDecoder.Memento) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- toMessage(ForkedProcessEventType, AbstractStreamDecoder.Memento) - Method in class org.apache.maven.surefire.stream.EventDecoder
- toMessage(MasterProcessCommand, AbstractStreamDecoder.Memento) - Method in class org.apache.maven.surefire.booter.stream.CommandDecoder
- toMinimalThrowableMiniMessage(Class<?>) - Static method in class org.apache.maven.surefire.report.SmartStackTraceParser
- toNewLines(String...) - Static method in exception org.apache.maven.surefire.booter.SurefireBooterForkException
- toNonNegative(double) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerUtil
- toNonNegative(long) - Static method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerUtil
- toolchain - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- toolchainManager - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- toOrdinals(Collection<? extends Enum<?>>) - Static method in class org.apache.maven.surefire.booter.SurefireReflector
- toPath(String...) - Static method in class org.apache.maven.plugin.surefire.util.FileScanner
- toProviderDependency(String, String) - Static method in class org.apache.maven.plugin.surefire.SurefireDependencyResolver
- toRealPath(Class<T>) - Method in class org.apache.maven.surefire.booter.AbstractPathConfiguration
- toReportEntry(List<Object>) - Static method in class org.apache.maven.surefire.stream.EventDecoder
- toReportEntryWithException(Object[]) - Method in class org.apache.maven.surefire.junit.TestListenerInvocationHandler
- toRunClass(String) - Static method in class org.apache.maven.surefire.api.booter.Command
- toRunResult(File) - Static method in class org.apache.maven.plugin.failsafe.util.FailsafeSummaryXmlUtils
- toShutdown(Shutdown) - Static method in class org.apache.maven.surefire.api.booter.Command
- toShutdownData() - Method in class org.apache.maven.surefire.api.booter.Command
- toSimpleClassName(String) - Static method in class org.apache.maven.surefire.report.SmartStackTraceParser
- toStackTrace(StackTraceWriter, boolean) - Static method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- toStackTraceWriter(Object[]) - Static method in class org.apache.maven.surefire.junit.TestListenerInvocationHandler
- toStackTraceWriter(String, String, Throwable) - Method in class org.apache.maven.surefire.junitplatform.RunListenerAdapter
- toStackTraceWriter(String, String, TestExecutionResult) - Method in class org.apache.maven.surefire.junitplatform.RunListenerAdapter
- toStackTraceWriter(List<Object>) - Static method in class org.apache.maven.surefire.stream.EventDecoder
- toString() - Method in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5ConsoleOutputReporter
- toString() - Method in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5StatelessTestsetInfoReporter
- toString() - Method in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5Xml30StatelessReporter
- toString() - Method in class org.apache.maven.plugin.surefire.extensions.SurefireConsoleOutputReporter
- toString() - Method in class org.apache.maven.plugin.surefire.extensions.SurefireStatelessTestsetInfoReporter
- toString() - Method in enum class org.apache.maven.surefire.api.booter.MasterProcessCommand
- toString() - Method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- toString() - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.BufferedStream
- toString() - Method in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- toString() - Method in class org.apache.maven.surefire.api.testset.TestListResolver
- toString() - Method in class org.apache.maven.surefire.api.util.RunOrder
- toString() - Method in class org.apache.maven.surefire.api.util.TestsToRun
- toString() - Method in class org.apache.maven.surefire.booter.IsolatedClassLoader
- toString() - Method in class org.apache.maven.surefire.booter.LazyTestsToRun
- toString() - Method in class org.apache.maven.surefire.booter.PpidChecker
- toString() - Method in class org.apache.maven.surefire.booter.TypeEncodedValue
- toString() - Method in class org.apache.maven.surefire.common.junit4.JUnit4Reflector.IgnoredWithUserError
- toString() - Method in class org.apache.maven.surefire.extensions.StatelessReporter
- toString() - Method in class org.apache.maven.surefire.junitcore.ConfigurableParallelComputer
-
Deprecated.
- toString() - Method in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- toString(Object) - Static method in class org.apache.maven.plugin.surefire.booterclient.BooterSerializer
- toString(String, String, Throwable, RunResult) - Static method in exception org.apache.maven.surefire.booter.SurefireBooterForkException
- toString(String, Throwable) - Static method in class org.apache.maven.plugin.surefire.log.api.ConsoleLoggerUtils
- toString(Throwable) - Static method in class org.apache.maven.plugin.surefire.log.api.ConsoleLoggerUtils
- toString(Throwable, Iterable<StackTraceElement>, StackTraceFilter) - Static method in class org.apache.maven.surefire.report.SmartStackTraceParser
- toString(List<String>) - Static method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder
- toString(RunResult) - Static method in exception org.apache.maven.surefire.booter.SurefireBooterForkException
- toStringProperties(Properties) - Static method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- TOTAL_POOL_SIZE_UNDEFINED - Static variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- totalPoolSize - Variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- totalPoolSize() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- totalRuntime - Variable in class org.apache.maven.surefire.api.runorder.Priority
- toTrace(String, String, String) - Static method in class org.apache.maven.surefire.stream.EventDecoder
- transformToClasses(List<PrioritizedTest>) - Static method in class org.apache.maven.surefire.api.runorder.RunEntryStatisticsMap
- trickClassPathWhenManifestOnlyClasspath() - Method in class org.apache.maven.surefire.booter.ClasspathConfiguration
- triggeredTests - Variable in class org.apache.maven.surefire.junitcore.pc.ShutdownResult
- triggerPingTimerForShutdown(Iterable<TestProvidingInputStream>) - Method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- triggerPingTimerForShutdown(TestLessInputStream.TestLessInputStreamBuilder) - Method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- triggerTimeoutCheck() - Method in class org.apache.maven.plugin.surefire.booterclient.ForkStarter
- trim - Variable in class org.apache.maven.surefire.api.booter.ForkingRunListener
- trimstackTrace - Variable in class org.apache.maven.surefire.api.booter.ForkingReporterFactory
- trimStackTrace - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Whether to trim the stack trace in the reports to just the lines within the test, or show the full trace.
- trimStackTrace - Variable in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- trimStackTrace - Variable in class org.apache.maven.plugin.surefire.report.TestSetStats
- trimStackTrace - Variable in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- trimStackTrace - Variable in class org.apache.maven.surefire.api.report.ReporterConfiguration
- trimStackTrace - Variable in class org.apache.maven.surefire.extensions.StatelessReportMojoConfiguration
- trimTrailingNewLine(String) - Static method in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- trouble - Variable in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- tryAcquireShared(int) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.QueueSynchronizer.SyncT1
- tryAcquireShared(int) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.QueueSynchronizer.SyncT2
- tryBlank(String) - Static method in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- tryConnectToClient() - Method in class org.apache.maven.plugin.surefire.extensions.LegacyForkChannel
- tryConnectToClient() - Method in class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel
- tryConnectToClient() - Method in class org.apache.maven.surefire.extensions.ForkChannel
-
Asynchronously connects to the client.
- tryFinish() - Method in class org.apache.maven.surefire.junitcore.pc.ShutdownStatus
- tryGetConstructor(Class<T>, Class<?>...) - Static method in class org.apache.maven.surefire.api.util.ReflectionUtils
- tryGetMethod(Class<?>, String, Class<?>...) - Static method in class org.apache.maven.surefire.api.util.ReflectionUtils
- tryGetMethod(Class<?>, String, Class<?>...) - Static method in class org.apache.maven.surefire.common.junit3.JUnit3Reflector
- tryLoadClass(ClassLoader, String) - Static method in class org.apache.maven.surefire.api.util.ReflectionUtils
- tryRelease() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.QueueSynchronizer.SyncT2
- tryReleaseShared(int) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.QueueSynchronizer.SyncT1
- tryReleaseShared(int) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.QueueSynchronizer.SyncT2
- tryTimeout() - Method in class org.apache.maven.surefire.junitcore.pc.ShutdownStatus
- tryToTimeout(long, int) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
-
Called in concurrent Thread.
- type - Variable in enum class org.apache.maven.surefire.booter.ProcessCheckerType
- type - Variable in class org.apache.maven.surefire.booter.TypeEncodedValue
- Type - Enum Class in org.apache.maven.surefire.junitcore.pc
- Type() - Constructor for enum class org.apache.maven.surefire.api.testset.ResolvedTest.Type
-
Deprecated.
- Type() - Constructor for enum class org.apache.maven.surefire.junitcore.pc.Type
- TypeEncodedValue - Class in org.apache.maven.surefire.booter
- TypeEncodedValue(String, String) - Constructor for class org.apache.maven.surefire.booter.TypeEncodedValue
U
- UNDERFLOW - Enum constant in enum class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.StreamReadStatus
- UNDETERMINED_TESTS_DESCRIPTION - Static variable in class org.apache.maven.surefire.junit4.JUnit4Provider
- unix() - Method in class org.apache.maven.surefire.booter.PpidChecker
- UNIX_CMD_OUT_PATTERN - Static variable in class org.apache.maven.surefire.booter.PpidChecker
-
The etime is in the form of [[dd-]hh:]mm:ss on Unix like systems.
- unixPathToPS() - Static method in class org.apache.maven.surefire.booter.PpidChecker
- unixProcessInfo(String, long) - Static method in class org.apache.maven.surefire.booter.ProcessInfo
-
On Unix we do not get PID due to the command is interested only to etime of PPID:
- unknown - Enum constant in enum class org.apache.maven.plugin.surefire.report.DefaultReporterFactory.TestResultType
- unmodifiableElements - Variable in class org.apache.maven.surefire.booter.Classpath
- UNSTABLE - Enum constant in enum class org.apache.maven.plugin.surefire.log.api.Level
-
defaults to bold, yellow
- UNUSED_DESCRIPTIONS - Static variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputerUtil
- unwrap(String) - Static method in class org.apache.maven.surefire.api.testset.TestListResolver
- unwrapRegex(String) - Static method in class org.apache.maven.surefire.api.testset.TestListResolver
- update(Command) - Method in interface org.apache.maven.surefire.api.provider.CommandListener
- updatedFilters(boolean, ResolvedTest, IncludedExcludedPatterns, Collection<ResolvedTest>, Collection<ResolvedTest>) - Static method in class org.apache.maven.surefire.api.testset.TestListResolver
- upgradeCheck() - Method in class org.apache.maven.surefire.junit4.JUnit4Provider
- uri - Variable in class org.apache.maven.plugin.surefire.booterclient.JarManifestForkConfiguration.ClasspathElementUri
- urls - Variable in class org.apache.maven.surefire.booter.IsolatedClassLoader
- useFile - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
Option to generate a file test report or just output the test report to the console.
- useFile - Variable in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- useFile - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
Option to generate a file test report or just output the test report to the console.
- useManifestOnlyJar - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
By default, Surefire forks your tests using a manifest-only JAR; set this parameter to "false" to force it to launch your tests with a plain old Java classpath.
- useManifestOnlyJar - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
By default, Surefire forks your tests using a manifest-only JAR; set this parameter to "false" to force it to launch your tests with a plain old Java classpath.
- useManifestOnlyJar - Variable in class org.apache.maven.surefire.booter.ClassLoaderConfiguration
- USEMANIFESTONLYJAR - Static variable in class org.apache.maven.surefire.booter.BooterConstants
- useModulePath - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
When
true
, uses the modulepath when executing with JDK 9+ and module-info.java is present. - useModulePath - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
When
true
, uses the modulepath when executing with JDK 9+ and module-info.java is present. - useModulePath() - Method in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
- useModulePath() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- useModulePath() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- useNonNull(T, T) - Static method in class org.apache.maven.surefire.api.util.internal.ObjectUtils
- useOnePool() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- useOnePool(int) - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- usePhrasedClassNameInRunning - Variable in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5StatelessTestsetInfoReporter
-
Phrased class name of test case in the console log (see xxx) Running xxx or file report log Test set: xxx.
- usePhrasedClassNameInRunning - Variable in class org.apache.maven.plugin.surefire.report.ConsoleReporter
- usePhrasedClassNameInRunning - Variable in class org.apache.maven.plugin.surefire.report.FileReporter
- usePhrasedClassNameInTestCaseSummary - Variable in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5StatelessTestsetInfoReporter
-
Phrased class name of test case in the log (see xxx) Tests run: ., Failures: ., Errors: ., Skipped: ., Time elapsed: .
- usePhrasedClassNameInTestCaseSummary - Variable in class org.apache.maven.plugin.surefire.report.ConsoleReporter
- usePhrasedClassNameInTestCaseSummary - Variable in class org.apache.maven.plugin.surefire.report.FileReporter
- usePhrasedFileName - Variable in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5ConsoleOutputReporter
-
false
by default. - usePhrasedFileName - Variable in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5StatelessTestsetInfoReporter
-
false
by default. - usePhrasedFileName - Variable in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5Xml30StatelessReporter
-
false
by default. - usePhrasedFileName - Variable in class org.apache.maven.plugin.surefire.report.ConsoleOutputFileReporter
- usePhrasedFileName - Variable in class org.apache.maven.plugin.surefire.report.FileReporter
- usePhrasedTestCaseClassName - Variable in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5Xml30StatelessReporter
-
false
by default. - usePhrasedTestCaseMethodName - Variable in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5Xml30StatelessReporter
-
false
by default. - usePhrasedTestSuiteClassName - Variable in class org.apache.maven.plugin.surefire.extensions.junit5.JUnit5Xml30StatelessReporter
-
false
by default. - useSeparatePools - Variable in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- useSeparatePools() - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder
- useSystemClassLoader - Variable in class org.apache.maven.plugin.failsafe.IntegrationTestMojo
-
Option to pass dependencies to the system's classloader instead of using an isolated class loader when forking.
- useSystemClassLoader - Variable in class org.apache.maven.plugin.surefire.SurefirePlugin
-
Option to pass dependencies to the system's classloader instead of using an isolated class loader when forking.
- useSystemClassLoader - Variable in class org.apache.maven.surefire.booter.ClassLoaderConfiguration
- USESYSTEMCLASSLOADER - Static variable in class org.apache.maven.surefire.booter.BooterConstants
- useUnlimitedThreads - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
(JUnit 4.7 provider) Indicates that the thread pool will be unlimited.
- useUnlimitedThreads - Variable in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- USEUNLIMITEDTHREADS_KEY - Static variable in class org.apache.maven.surefire.junitcore.JUnitCoreParameters
- Utf8RecodingDeferredFileOutputStream - Class in org.apache.maven.plugin.surefire.report
-
A deferred file output stream decorator that recodes the bytes written into the stream from the VM default encoding to UTF-8.
- Utf8RecodingDeferredFileOutputStream(String) - Constructor for class org.apache.maven.plugin.surefire.report.Utf8RecodingDeferredFileOutputStream
V
- value - Variable in class org.apache.maven.surefire.api.event.SystemPropertyEvent
- value - Variable in class org.apache.maven.surefire.api.util.internal.ImmutableMap.Node
- value - Variable in class org.apache.maven.surefire.booter.TypeEncodedValue
- value - Variable in class org.apache.maven.surefire.common.junit4.JUnit4Reflector.IgnoredWithUserError
- value() - Method in class org.apache.maven.surefire.common.junit4.JUnit4Reflector.IgnoredWithUserError
- valueOf(String) - Static method in enum class org.apache.maven.plugin.surefire.AbstractSurefireMojo.PluginFailureReason
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.maven.plugin.surefire.log.api.Level
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.maven.plugin.surefire.report.DefaultReporterFactory.TestResultType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.maven.plugin.surefire.report.ReportEntryType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.maven.surefire.api.booter.MasterProcessCommand
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.maven.surefire.api.booter.Shutdown
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.maven.surefire.api.cli.CommandLineOption
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.maven.surefire.api.report.RunMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.StreamReadStatus
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.maven.surefire.api.stream.SegmentType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.maven.surefire.api.testset.ResolvedTest.Type
-
Deprecated.Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in class org.apache.maven.surefire.api.util.RunOrder
- valueOf(String) - Static method in enum class org.apache.maven.surefire.booter.ProcessCheckerType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.maven.surefire.junitcore.pc.ExecutionStatus
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.maven.surefire.junitcore.pc.Type
-
Returns the enum constant of this class with the specified name.
- valueOfMulti(String) - Static method in class org.apache.maven.surefire.api.util.RunOrder
-
Returns the specified RunOrder
- values() - Static method in enum class org.apache.maven.plugin.surefire.AbstractSurefireMojo.PluginFailureReason
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.maven.plugin.surefire.log.api.Level
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.maven.plugin.surefire.report.DefaultReporterFactory.TestResultType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.maven.plugin.surefire.report.ReportEntryType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.maven.surefire.api.booter.ForkedProcessEventType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.maven.surefire.api.booter.MasterProcessCommand
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.maven.surefire.api.booter.Shutdown
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.maven.surefire.api.cli.CommandLineOption
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.maven.surefire.api.report.RunMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.StreamReadStatus
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.maven.surefire.api.stream.SegmentType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.maven.surefire.api.testset.ResolvedTest.Type
-
Deprecated.Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in class org.apache.maven.surefire.api.util.RunOrder
- values() - Static method in enum class org.apache.maven.surefire.booter.ProcessCheckerType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.maven.surefire.junitcore.pc.ExecutionStatus
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.maven.surefire.junitcore.pc.Type
-
Returns an array containing the constants of this enum class, in the order they are declared.
- VerifyMojo - Class in org.apache.maven.plugin.failsafe
-
Verify integration tests ran using Surefire.
- VerifyMojo() - Constructor for class org.apache.maven.plugin.failsafe.VerifyMojo
- verifyParameters() - Method in class org.apache.maven.plugin.failsafe.VerifyMojo
- verifyParameters() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- verifySessionId() - Method in class org.apache.maven.plugin.surefire.extensions.SurefireForkChannel
- version - Variable in class org.apache.maven.surefire.api.testset.TestArtifactInfo
- version - Variable in class org.apache.maven.surefire.extensions.StatelessReporter
-
Version of reporter.
W
- waitForCompletion() - Method in class org.apache.maven.surefire.junitcore.AsynchronousRunner
-
Deprecated.
- waitIfZero() - Method in class org.apache.maven.plugin.surefire.booterclient.output.ThreadedStreamConsumer.QueueSynchronizer.SyncT1
- wakeupIterator() - Method in class org.apache.maven.surefire.booter.CommandReader
- warnIfDefunctGroupsCombinations() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- warnIfForkCountIsZero() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- warnIfIllegalFailOnFlakeCount() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- warnIfIllegalFailOnFlakeCount() - Method in class org.apache.maven.plugin.surefire.SurefirePlugin
- warnIfIllegalTempDir() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- warnIfNotApplicableSkipAfterFailureCount() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- warnIfRerunClashes() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- warnIfUselessUseSystemClassLoaderParameter() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- warnIfWrongShutdownValue() - Method in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
- warning(CharSequence, Throwable) - Method in class org.apache.maven.plugin.surefire.log.PluginConsoleLogger
- warning(String) - Method in interface org.apache.maven.plugin.surefire.log.api.ConsoleLogger
- warning(String) - Method in class org.apache.maven.plugin.surefire.log.api.ConsoleLoggerDecorator
- warning(String) - Method in class org.apache.maven.plugin.surefire.log.api.NullConsoleLogger
- warning(String) - Method in class org.apache.maven.plugin.surefire.log.api.PrintStreamLogger
- warning(String) - Method in class org.apache.maven.plugin.surefire.log.PluginConsoleLogger
- warning(String) - Method in class org.apache.maven.plugin.surefire.report.DefaultReporterFactory
- warning(String) - Method in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- warning(String) - Method in class org.apache.maven.surefire.api.booter.ForkingRunListener
- warning(String) - Method in class org.apache.maven.surefire.junitcore.ConcurrentRunListener
-
Deprecated.
- WarningListener() - Constructor for class org.apache.maven.plugin.surefire.booterclient.output.ForkClient.WarningListener
- WILDCARD - Static variable in class org.apache.maven.surefire.api.testset.TestListResolver
- WILDCARD_FILENAME_POSTFIX - Static variable in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- WILDCARD_PATH_PREFIX - Static variable in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- windows() - Method in class org.apache.maven.surefire.booter.PpidChecker
- WINDOWS_SYSTEM_ROOT_ENV - Static variable in class org.apache.maven.surefire.booter.PpidChecker
- windowsProcessInfo(String, long) - Static method in class org.apache.maven.surefire.booter.ProcessInfo
- withException(RunMode, Long, String, String, String, String, StackTraceWriter) - Static method in class org.apache.maven.surefire.api.report.SimpleReportEntry
- withJdkExecAttributesForTests(JdkAttributes) - Method in class org.apache.maven.plugin.surefire.booterclient.Platform
- withReportedTests(Class<?>...) - Method in class org.apache.maven.surefire.junitcore.JUnitCoreWrapper.JUnitCore
- WMIC_CREATION_DATE - Static variable in class org.apache.maven.surefire.booter.PpidChecker
- WMIC_CREATION_DATE_FORMAT - Static variable in class org.apache.maven.surefire.booter.PpidChecker
- WMIC_CREATION_DATE_TIMESTAMP_LENGTH - Static variable in class org.apache.maven.surefire.booter.PpidChecker
- WMIC_CREATION_DATE_VALUE_LENGTH - Static variable in class org.apache.maven.surefire.booter.PpidChecker
- workingDirectory - Variable in class org.apache.maven.plugin.surefire.AbstractSurefireMojo
-
Command line working directory.
- workingDirectory - Variable in class org.apache.maven.plugin.surefire.booterclient.DefaultForkConfiguration
- wrap(ReportEntry, ReportEntryType) - Method in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- WrappedReportEntry - Class in org.apache.maven.plugin.surefire.report
- WrappedReportEntry(ReportEntry, ReportEntryType, Integer, Utf8RecodingDeferredFileOutputStream, Utf8RecodingDeferredFileOutputStream) - Constructor for class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- WrappedReportEntry(ReportEntry, ReportEntryType, Integer, Utf8RecodingDeferredFileOutputStream, Utf8RecodingDeferredFileOutputStream, Map<String, String>) - Constructor for class org.apache.maven.plugin.surefire.report.WrappedReportEntry
- WrappedRunners - Class in org.apache.maven.surefire.junitcore.pc
-
We need to wrap runners in a suite and count children of these runners.
- WrappedRunners() - Constructor for class org.apache.maven.surefire.junitcore.pc.WrappedRunners
- WrappedRunners(ParentRunner, long) - Constructor for class org.apache.maven.surefire.junitcore.pc.WrappedRunners
- wrappingSuite - Variable in class org.apache.maven.surefire.junitcore.pc.WrappedRunners
- wrapRegex(String) - Static method in class org.apache.maven.surefire.api.testset.ResolvedTest
-
Deprecated.
- wrapRunners(Collection<T>) - Method in class org.apache.maven.surefire.junitcore.pc.ParallelComputerBuilder.PC
- wrapTask(Runnable) - Method in class org.apache.maven.surefire.junitcore.pc.Scheduler
- wrapTestSet(TestSetReportEntry) - Method in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- WritableBufferedByteChannel - Interface in org.apache.maven.surefire.api.util.internal
-
Extends
WritableByteChannel
with buffered (i.e. - write(byte[]) - Method in class org.apache.maven.surefire.api.report.ConsoleOutputCapture.ForwardingPrintStream
- write(byte[], int, int) - Method in class org.apache.maven.surefire.api.report.ConsoleOutputCapture.ForwardingPrintStream
- write(int) - Method in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter.EncodingOutputStream
- write(int) - Method in class org.apache.maven.surefire.api.report.ConsoleOutputCapture.ForwardingPrintStream
- write(int) - Method in class org.apache.maven.surefire.api.report.ConsoleOutputCapture.NullOutputStream
- write(String, boolean) - Method in class org.apache.maven.plugin.surefire.report.Utf8RecodingDeferredFileOutputStream
- write(ByteBuffer) - Method in class org.apache.maven.surefire.api.util.internal.AbstractNoninterruptibleWritableChannel
- write(ByteBuffer, boolean) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamEncoder
- write(ByteBuffer, boolean) - Method in class org.apache.maven.surefire.api.util.internal.AbstractNoninterruptibleWritableChannel
- write(ByteBuffer, boolean) - Method in class org.apache.maven.surefire.booter.spi.EventChannelEncoder
- write(ByteBuffer, int, int) - Method in class org.apache.maven.surefire.api.stream.AbstractStreamDecoder.BufferedStream
- write(TestOutputReportEntry) - Method in class org.apache.maven.surefire.junitcore.LogicalStream
-
Deprecated.
- writeBuffered(ByteBuffer) - Method in class org.apache.maven.surefire.api.util.internal.AbstractNoninterruptibleWritableChannel
- writeBuffered(ByteBuffer) - Method in interface org.apache.maven.surefire.api.util.internal.WritableBufferedByteChannel
- writeDetails(TestOutputReceiver<TestOutputReportEntry>) - Method in class org.apache.maven.surefire.junitcore.LogicalStream
-
Deprecated.
- writeImpl(ByteBuffer) - Method in class org.apache.maven.surefire.api.util.internal.AbstractNoninterruptibleWritableChannel
- writePropertiesFile(File, String, Properties) - Static method in class org.apache.maven.surefire.booter.SystemPropertyManager
- writePropertiesFile(Properties, File, String, boolean) - Static method in class org.apache.maven.surefire.booter.SystemPropertyManager
- writeSummary(RunResult, File, boolean) - Static method in class org.apache.maven.plugin.failsafe.util.FailsafeSummaryXmlUtils
- writeSurefireTestClasspathProperty() - Method in class org.apache.maven.surefire.booter.StartupConfiguration
- writeTestOutput(String, boolean, boolean, RunMode, Long) - Method in class org.apache.maven.plugin.surefire.booterclient.output.ForkClient
- writeTestOutput(OutputReportEntry) - Method in class org.apache.maven.surefire.common.junit4.JUnit4RunListener
- writeTestOutput(OutputReportEntry) - Method in class org.apache.maven.surefire.junit.JUnit3Reporter
- writeTestOutput(OutputReportEntry) - Method in class org.apache.maven.surefire.junitplatform.RunListenerAdapter
- writeTestOutput(OutputReportEntry) - Method in class org.apache.maven.surefire.testng.TestNGReporter
- writeTestOutput(TestOutputReportEntry) - Method in class org.apache.maven.plugin.surefire.report.ConsoleOutputFileReporter
- writeTestOutput(TestOutputReportEntry) - Method in class org.apache.maven.plugin.surefire.report.DirectConsoleOutput
- writeTestOutput(TestOutputReportEntry) - Method in class org.apache.maven.plugin.surefire.report.NullConsoleOutputReceiver
- writeTestOutput(TestOutputReportEntry) - Method in class org.apache.maven.plugin.surefire.report.TestSetRunListener
- writeTestOutput(TestOutputReportEntry) - Method in class org.apache.maven.surefire.api.booter.ForkingRunListener
- writeTestOutput(TestOutputReportEntry) - Method in interface org.apache.maven.surefire.extensions.ConsoleOutputReportEventListener
- writeTestOutput(TestOutputReportEntry) - Method in class org.apache.maven.surefire.junitcore.ConcurrentRunListener
-
Deprecated.
- writeTestOutput(TestOutputReportEntry) - Method in class org.apache.maven.surefire.junitcore.TestMethod
-
Deprecated.
- writeTestOutput(T) - Method in interface org.apache.maven.surefire.api.report.TestOutputReceiver
-
Forwards process output from the running test-case into the reporting system
- writeTo(OutputStream) - Method in class org.apache.maven.plugin.surefire.report.Utf8RecodingDeferredFileOutputStream
- writeTo(Map<String, String>) - Method in class org.apache.maven.surefire.api.util.DefaultScanResult
- writeTo(Map<String, String>) - Method in interface org.apache.maven.surefire.api.util.ScanResult
- writeToSystemProperty(String) - Method in class org.apache.maven.surefire.booter.Classpath
- writeTraceToString() - Method in class org.apache.maven.plugin.surefire.booterclient.output.DeserializedStacktraceWriter
- writeTraceToString() - Method in class org.apache.maven.surefire.api.report.LegacyPojoStackTraceWriter
- writeTraceToString() - Method in interface org.apache.maven.surefire.api.report.StackTraceWriter
-
Write the throwable to a string, without trimming.
- writeTraceToString() - Method in class org.apache.maven.surefire.common.junit4.JUnit4StackTraceWriter
- writeTraceToString() - Method in class org.apache.maven.surefire.report.PojoStackTraceWriter
- writeTrimmedTraceToString() - Method in class org.apache.maven.plugin.surefire.booterclient.output.DeserializedStacktraceWriter
- writeTrimmedTraceToString() - Method in class org.apache.maven.surefire.api.report.LegacyPojoStackTraceWriter
- writeTrimmedTraceToString() - Method in interface org.apache.maven.surefire.api.report.StackTraceWriter
-
Write the throwable to a string, trimming extra locations.
- writeTrimmedTraceToString() - Method in class org.apache.maven.surefire.common.junit4.JUnit4StackTraceWriter
-
At the moment, returns the same as
JUnit4StackTraceWriter.writeTraceToString()
. - writeTrimmedTraceToString() - Method in class org.apache.maven.surefire.report.PojoStackTraceWriter
X
- XML_CLASS_CONSTRUCTOR_WITH_INDEX - Static variable in class org.apache.maven.surefire.testng.TestNGExecutor
- XML_CLASS_SET_INDEX - Static variable in class org.apache.maven.surefire.testng.TestNGExecutor
- XML_INDENT - Static variable in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- XML_NL - Static variable in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- xmlReporter - Variable in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- xmlSuite - Variable in class org.apache.maven.surefire.testng.TestNGExecutor.SuiteAndNamedTests
- xmlTag - Variable in enum class org.apache.maven.plugin.surefire.report.ReportEntryType
- xsdSchemaLocation - Variable in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
- xsdSchemaLocation - Variable in class org.apache.maven.plugin.surefire.StartupReportConfiguration
- xsdSchemaLocation - Variable in class org.apache.maven.surefire.extensions.StatelessReportMojoConfiguration
- xsdVersion - Variable in class org.apache.maven.plugin.surefire.report.StatelessXmlReporter
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
File
instead ofURL
in the next major version.