NIFI-3440 This closes #1638. fixing tests not written for windows to not run on windows

This commit is contained in:
joewitt 2017-03-31 01:38:37 -04:00
parent 091359b450
commit 6a64b3cd9c
11 changed files with 122 additions and 27 deletions

View File

@ -96,6 +96,7 @@ import static org.junit.Assert.assertNotNull;
import static org.junit.Assert.assertNull;
import static org.junit.Assert.assertTrue;
import static org.junit.Assert.fail;
import static org.junit.Assume.assumeFalse;
public class TestHttpClient {
@ -1128,7 +1129,7 @@ public class TestHttpClient {
@Test
public void testSendTimeout() throws Exception {
assumeFalse(isWindowsEnvironment());//skip on windows
try (
SiteToSiteClient client = getDefaultBuilder()
.timeout(1, TimeUnit.SECONDS)
@ -1160,9 +1161,13 @@ public class TestHttpClient {
}
private boolean isWindowsEnvironment() {
return System.getProperty("os.name").toLowerCase().startsWith("windows");
}
@Test
public void testSendTimeoutAfterDataExchange() throws Exception {
assumeFalse(isWindowsEnvironment());//skip on windows
System.setProperty("org.slf4j.simpleLogger.log.org.apache.nifi.remote.protocol.http.HttpClientTransaction", "INFO");
try (

View File

@ -61,6 +61,7 @@ import ch.qos.logback.classic.Level;
import ch.qos.logback.classic.Logger;
import ch.qos.logback.classic.spi.ILoggingEvent;
import ch.qos.logback.core.read.ListAppender;
import static org.junit.Assume.assumeFalse;
public class TestFileSystemRepository {
@ -102,7 +103,6 @@ public class TestFileSystemRepository {
random.nextBytes(content);
// final ContentClaimWriteCache cache = new ContentClaimWriteCache(repository);
final long start = System.nanoTime();
for (int i = 0; i < iterations; i++) {
final ContentClaim claim = repository.create(false);
@ -120,7 +120,7 @@ public class TestFileSystemRepository {
final long seconds = millis / 1000L;
final double mbps = (double) mb / (double) seconds;
System.out.println("Took " + millis + " millis to write " + contentSize + " bytes " + iterations + " times (total of "
+ NumberFormat.getNumberInstance(Locale.US).format(bytesToWrite) + " bytes) for a write rate of " + mbps + " MB/s");
+ NumberFormat.getNumberInstance(Locale.US).format(bytesToWrite) + " bytes) for a write rate of " + mbps + " MB/s");
}
@Test
@ -438,6 +438,7 @@ public class TestFileSystemRepository {
@Test
public void testReadWithContentArchived() throws IOException {
assumeFalse(isWindowsEnvironment());//skip if on windows
final ContentClaim claim = repository.create(true);
final Path path = getPath(claim);
Files.deleteIfExists(path);
@ -457,8 +458,13 @@ public class TestFileSystemRepository {
}
}
private boolean isWindowsEnvironment() {
return System.getProperty("os.name").toLowerCase().startsWith("windows");
}
@Test(expected = ContentNotFoundException.class)
public void testReadWithNoContentArchived() throws IOException {
assumeFalse(isWindowsEnvironment());//skip if on windows
final ContentClaim claim = repository.create(true);
final Path path = getPath(claim);
Files.deleteIfExists(path);

View File

@ -29,6 +29,7 @@ import org.apache.nifi.util.TestRunners;
import org.junit.Test;
import static org.junit.Assert.assertTrue;
import static org.junit.Assert.fail;
import static org.junit.Assume.assumeFalse;
import org.junit.Before;
import static org.mockito.Matchers.anyObject;
import static org.mockito.Mockito.atLeast;
@ -167,8 +168,13 @@ public class ConsumeKafkaTest {
verifyNoMoreInteractions(mockLease);
}
private boolean isWindowsEnvironment() {
return System.getProperty("os.name").toLowerCase().startsWith("windows");
}
@Test
public void validateConsumerRetainer() throws Exception {
assumeFalse(isWindowsEnvironment());//skip if on windows
final ConsumerPool consumerPool = mock(ConsumerPool.class);
final ConsumeKafka processor = new ConsumeKafka() {

View File

@ -90,6 +90,7 @@ import org.apache.nifi.util.NiFiProperties;
import org.apache.nifi.util.file.FileUtils;
import org.junit.After;
import org.junit.Assert;
import static org.junit.Assume.assumeFalse;
import org.junit.Before;
import org.junit.BeforeClass;
import org.junit.ClassRule;
@ -238,8 +239,6 @@ public class TestPersistentProvenanceRepository {
}
}
private EventReporter getEventReporter() {
return eventReporter;
}
@ -360,6 +359,7 @@ public class TestPersistentProvenanceRepository {
@Test
public void testAddAndRecover() throws IOException, InterruptedException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration config = createConfiguration();
config.setMaxEventFileCapacity(1L);
config.setMaxEventFileLife(1, TimeUnit.SECONDS);
@ -405,6 +405,7 @@ public class TestPersistentProvenanceRepository {
@Test
public void testAddToMultipleLogsAndRecover() throws IOException, InterruptedException {
assumeFalse(isWindowsEnvironment());
final List<SearchableField> searchableFields = new ArrayList<>();
searchableFields.add(SearchableFields.ComponentID);
@ -463,6 +464,7 @@ public class TestPersistentProvenanceRepository {
@Test
public void testIndexOnRolloverWithImmenseAttribute() throws IOException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration config = createConfiguration();
config.setMaxEventFileLife(500, TimeUnit.MILLISECONDS);
config.setSearchableFields(new ArrayList<>(SearchableFields.getStandardFields()));
@ -472,7 +474,7 @@ public class TestPersistentProvenanceRepository {
int immenseAttrSize = 33000; // must be greater than 32766 for a meaningful test
StringBuilder immenseBldr = new StringBuilder(immenseAttrSize);
for (int i=0; i < immenseAttrSize; i++) {
for (int i = 0; i < immenseAttrSize; i++) {
immenseBldr.append('0');
}
final String uuid = "00000000-0000-0000-0000-000000000000";
@ -508,6 +510,7 @@ public class TestPersistentProvenanceRepository {
@Test
public void testIndexOnRolloverAndSubsequentSearch() throws IOException, InterruptedException, ParseException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration config = createConfiguration();
config.setMaxEventFileLife(500, TimeUnit.MILLISECONDS);
config.setSearchableFields(new ArrayList<>(SearchableFields.getStandardFields()));
@ -552,6 +555,7 @@ public class TestPersistentProvenanceRepository {
@Test
public void testCompressOnRollover() throws IOException, InterruptedException, ParseException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration config = createConfiguration();
config.setMaxEventFileLife(500, TimeUnit.MILLISECONDS);
config.setCompressOnRollover(true);
@ -586,6 +590,7 @@ public class TestPersistentProvenanceRepository {
@Test
public void testIndexAndCompressOnRolloverAndSubsequentSearch() throws IOException, InterruptedException, ParseException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration config = createConfiguration();
config.setMaxRecordLife(30, TimeUnit.SECONDS);
config.setMaxStorageCapacity(1024L * 1024L * 10);
@ -645,6 +650,7 @@ public class TestPersistentProvenanceRepository {
@Test(timeout = 10000)
public void testModifyIndexWhileSearching() throws IOException, InterruptedException, ParseException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration config = createConfiguration();
config.setMaxRecordLife(30, TimeUnit.SECONDS);
config.setMaxStorageCapacity(1024L * 1024L * 10);
@ -804,6 +810,7 @@ public class TestPersistentProvenanceRepository {
@Test
public void testIndexAndCompressOnRolloverAndSubsequentSearchMultipleStorageDirs() throws IOException, InterruptedException, ParseException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration config = createConfiguration();
config.addStorageDirectory("2", new File("target/storage/" + UUID.randomUUID().toString()));
config.setMaxRecordLife(30, TimeUnit.SECONDS);
@ -892,6 +899,7 @@ public class TestPersistentProvenanceRepository {
@Test
public void testIndexAndCompressOnRolloverAndSubsequentEmptySearch() throws IOException, InterruptedException, ParseException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration config = createConfiguration();
config.setMaxRecordLife(30, TimeUnit.SECONDS);
config.setMaxStorageCapacity(1024L * 1024L);
@ -948,6 +956,7 @@ public class TestPersistentProvenanceRepository {
@Test
public void testLineageReceiveDrop() throws IOException, InterruptedException, ParseException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration config = createConfiguration();
config.setMaxRecordLife(3, TimeUnit.SECONDS);
config.setMaxStorageCapacity(1024L * 1024L);
@ -1003,6 +1012,7 @@ public class TestPersistentProvenanceRepository {
@Test
public void testLineageReceiveDropAsync() throws IOException, InterruptedException, ParseException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration config = createConfiguration();
config.setMaxRecordLife(3, TimeUnit.SECONDS);
config.setMaxStorageCapacity(1024L * 1024L);
@ -1062,6 +1072,7 @@ public class TestPersistentProvenanceRepository {
@Test
public void testLineageManyToOneSpawn() throws IOException, InterruptedException, ParseException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration config = createConfiguration();
config.setMaxRecordLife(3, TimeUnit.SECONDS);
config.setMaxStorageCapacity(1024L * 1024L);
@ -1112,6 +1123,7 @@ public class TestPersistentProvenanceRepository {
@Test
public void testLineageManyToOneSpawnAsync() throws IOException, InterruptedException, ParseException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration config = createConfiguration();
config.setMaxRecordLife(3, TimeUnit.SECONDS);
config.setMaxStorageCapacity(1024L * 1024L);
@ -1164,6 +1176,7 @@ public class TestPersistentProvenanceRepository {
@Test
public void testCorrectProvenanceEventIdOnRestore() throws IOException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration config = createConfiguration();
config.setMaxEventFileLife(1, TimeUnit.SECONDS);
repo = new PersistentProvenanceRepository(config, DEFAULT_ROLLOVER_MILLIS);
@ -1213,6 +1226,7 @@ public class TestPersistentProvenanceRepository {
*/
@Test
public void testWithWithEventFileMissingRecord() throws Exception {
assumeFalse(isWindowsEnvironment());
File eventFile = this.prepCorruptedEventFileTests();
final Query query = new Query(UUID.randomUUID().toString());
@ -1234,6 +1248,7 @@ public class TestPersistentProvenanceRepository {
*/
@Test
public void testWithWithEventFileCorrupted() throws Exception {
assumeFalse(isWindowsEnvironment());
File eventFile = this.prepCorruptedEventFileTests();
final Query query = new Query(UUID.randomUUID().toString());
@ -1358,6 +1373,7 @@ public class TestPersistentProvenanceRepository {
@Test
public void testNotAuthorizedGetSpecificEvent() throws IOException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration config = createConfiguration();
config.setMaxRecordLife(5, TimeUnit.MINUTES);
config.setMaxStorageCapacity(1024L * 1024L);
@ -1409,6 +1425,7 @@ public class TestPersistentProvenanceRepository {
@Test
public void testNotAuthorizedGetEventRange() throws IOException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration config = createConfiguration();
config.setMaxRecordLife(5, TimeUnit.MINUTES);
config.setMaxStorageCapacity(1024L * 1024L);
@ -1461,6 +1478,7 @@ public class TestPersistentProvenanceRepository {
@Test(timeout = 10000)
public void testNotAuthorizedQuery() throws IOException, InterruptedException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration config = createConfiguration();
config.setMaxRecordLife(5, TimeUnit.MINUTES);
config.setMaxStorageCapacity(1024L * 1024L);
@ -1519,9 +1537,9 @@ public class TestPersistentProvenanceRepository {
}
}
@Test(timeout = 1000000)
public void testNotAuthorizedLineage() throws IOException, InterruptedException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration config = createConfiguration();
config.setMaxRecordLife(5, TimeUnit.MINUTES);
config.setMaxStorageCapacity(1024L * 1024L);
@ -1603,9 +1621,9 @@ public class TestPersistentProvenanceRepository {
assertEquals(5, lineageNodes.stream().map(node -> node.getNodeType()).filter(t -> t == LineageNodeType.PROVENANCE_EVENT_NODE).count());
final Set<EventNode> eventNodes = lineageNodes.stream()
.filter(node -> node.getNodeType() == LineageNodeType.PROVENANCE_EVENT_NODE)
.map(node -> (EventNode) node)
.collect(Collectors.toSet());
.filter(node -> node.getNodeType() == LineageNodeType.PROVENANCE_EVENT_NODE)
.map(node -> (EventNode) node)
.collect(Collectors.toSet());
final Map<ProvenanceEventType, List<EventNode>> nodesByType = eventNodes.stream().collect(Collectors.groupingBy(EventNode::getEventType));
assertEquals(1, nodesByType.get(ProvenanceEventType.RECEIVE).size());
@ -1629,9 +1647,9 @@ public class TestPersistentProvenanceRepository {
assertEquals(3, expandChildNodes.stream().map(node -> node.getNodeType()).filter(t -> t == LineageNodeType.PROVENANCE_EVENT_NODE).count());
final Set<EventNode> childEventNodes = expandChildNodes.stream()
.filter(node -> node.getNodeType() == LineageNodeType.PROVENANCE_EVENT_NODE)
.map(node -> (EventNode) node)
.collect(Collectors.toSet());
.filter(node -> node.getNodeType() == LineageNodeType.PROVENANCE_EVENT_NODE)
.map(node -> (EventNode) node)
.collect(Collectors.toSet());
final Map<ProvenanceEventType, List<EventNode>> childNodesByType = childEventNodes.stream().collect(Collectors.groupingBy(EventNode::getEventType));
assertEquals(1, childNodesByType.get(ProvenanceEventType.FORK).size());
@ -1640,10 +1658,9 @@ public class TestPersistentProvenanceRepository {
assertNull(childNodesByType.get(ProvenanceEventType.ATTRIBUTES_MODIFIED));
}
@Test
public void testBackPressure() throws IOException, InterruptedException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration config = createConfiguration();
config.setMaxEventFileCapacity(1L); // force rollover on each record.
config.setJournalCount(1);
@ -1708,6 +1725,7 @@ public class TestPersistentProvenanceRepository {
@Test
public void testTextualQuery() throws InterruptedException, IOException, ParseException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration config = createConfiguration();
config.setMaxEventFileLife(500, TimeUnit.MILLISECONDS);
config.setSearchableFields(new ArrayList<>(SearchableFields.getStandardFields()));
@ -1753,6 +1771,7 @@ public class TestPersistentProvenanceRepository {
}
private List<Document> runQuery(final File indexDirectory, final List<File> storageDirs, final String query) throws IOException, ParseException {
assumeFalse(isWindowsEnvironment());
try (final DirectoryReader directoryReader = DirectoryReader.open(FSDirectory.open(indexDirectory))) {
final IndexSearcher searcher = new IndexSearcher(directoryReader);
@ -1798,6 +1817,7 @@ public class TestPersistentProvenanceRepository {
@Test
public void testMergeJournals() throws IOException, InterruptedException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration config = createConfiguration();
config.setMaxEventFileLife(3, TimeUnit.SECONDS);
repo = new PersistentProvenanceRepository(config, DEFAULT_ROLLOVER_MILLIS);
@ -1847,7 +1867,7 @@ public class TestPersistentProvenanceRepository {
}
private void corruptJournalFile(final File journalFile, final int position,
final String original, final String replacement) throws IOException {
final String original, final String replacement) throws IOException {
final int journalLength = Long.valueOf(journalFile.length()).intValue();
final byte[] origBytes = original.getBytes();
final byte[] replBytes = replacement.getBytes();
@ -1865,6 +1885,7 @@ public class TestPersistentProvenanceRepository {
@Test
public void testMergeJournalsBadFirstRecord() throws IOException, InterruptedException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration config = createConfiguration();
config.setMaxEventFileLife(3, TimeUnit.SECONDS);
TestablePersistentProvenanceRepository testRepo = new TestablePersistentProvenanceRepository(config, DEFAULT_ROLLOVER_MILLIS);
@ -1901,7 +1922,7 @@ public class TestPersistentProvenanceRepository {
}
}
RecordWriter firstWriter = testRepo.getWriters()[0];
corruptJournalFile(firstWriter.getFile(), headerSize + 15,"RECEIVE", "BADTYPE");
corruptJournalFile(firstWriter.getFile(), headerSize + 15, "RECEIVE", "BADTYPE");
testRepo.recoverJournalFiles();
@ -1911,6 +1932,7 @@ public class TestPersistentProvenanceRepository {
@Test
public void testMergeJournalsBadRecordAfterFirst() throws IOException, InterruptedException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration config = createConfiguration();
config.setMaxEventFileLife(3, TimeUnit.SECONDS);
TestablePersistentProvenanceRepository testRepo = new TestablePersistentProvenanceRepository(config, DEFAULT_ROLLOVER_MILLIS);
@ -1955,8 +1977,13 @@ public class TestPersistentProvenanceRepository {
assertTrue(checkJournalRecords(storageDir, false) < 10000);
}
private boolean isWindowsEnvironment() {
return System.getProperty("os.name").toLowerCase().startsWith("windows");
}
@Test
public void testMergeJournalsEmptyJournal() throws IOException, InterruptedException {
assumeFalse(isWindowsEnvironment());//skip on window
final RepositoryConfiguration config = createConfiguration();
config.setMaxEventFileLife(3, TimeUnit.SECONDS);
TestablePersistentProvenanceRepository testRepo = new TestablePersistentProvenanceRepository(config, DEFAULT_ROLLOVER_MILLIS);
@ -2003,11 +2030,12 @@ public class TestPersistentProvenanceRepository {
@Test
public void testRolloverRetry() throws IOException, InterruptedException {
assumeFalse(isWindowsEnvironment());
final AtomicInteger retryAmount = new AtomicInteger(0);
final RepositoryConfiguration config = createConfiguration();
config.setMaxEventFileLife(3, TimeUnit.SECONDS);
repo = new PersistentProvenanceRepository(config, DEFAULT_ROLLOVER_MILLIS){
repo = new PersistentProvenanceRepository(config, DEFAULT_ROLLOVER_MILLIS) {
@Override
File mergeJournals(List<File> journalFiles, File suggestedMergeFile, EventReporter eventReporter) throws IOException {
retryAmount.incrementAndGet();
@ -2053,11 +2081,12 @@ public class TestPersistentProvenanceRepository {
exec.awaitTermination(10, TimeUnit.SECONDS);
repo.waitForRollover();
assertEquals(5,retryAmount.get());
assertEquals(5, retryAmount.get());
}
@Test
public void testTruncateAttributes() throws IOException, InterruptedException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration config = createConfiguration();
config.setMaxAttributeChars(50);
config.setMaxEventFileLife(3, TimeUnit.SECONDS);
@ -2094,9 +2123,9 @@ public class TestPersistentProvenanceRepository {
assertEquals(maxLengthChars.substring(0, 49), retrieved.getAttributes().get("49chars"));
}
@Test(timeout = 15000)
public void testExceptionOnIndex() throws IOException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration config = createConfiguration();
config.setMaxAttributeChars(50);
config.setMaxEventFileLife(3, TimeUnit.SECONDS);
@ -2134,7 +2163,7 @@ public class TestPersistentProvenanceRepository {
builder.setComponentId("1234");
builder.setComponentType("dummy processor");
for (int i=0; i < 1000; i++) {
for (int i = 0; i < 1000; i++) {
final ProvenanceEventRecord record = builder.build();
repo.registerEvent(record);
}
@ -2149,6 +2178,7 @@ public class TestPersistentProvenanceRepository {
@Test
public void testFailureToCreateWriterDoesNotPreventSubsequentRollover() throws IOException, InterruptedException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration config = createConfiguration();
config.setMaxAttributeChars(50);
config.setMaxEventFileLife(3, TimeUnit.SECONDS);
@ -2207,8 +2237,8 @@ public class TestPersistentProvenanceRepository {
assertEquals(0, reportedEvents.size());
}
private static class ReportedEvent {
private final Severity severity;
private final String category;
private final String message;
@ -2310,7 +2340,7 @@ public class TestPersistentProvenanceRepository {
try {
createRepositoryConfigurationMethod = klass.getDeclaredMethod("createRepositoryConfiguration", NiFiProperties.class);
createRepositoryConfigurationMethod.setAccessible(true);
configuration = (RepositoryConfiguration)createRepositoryConfigurationMethod.invoke(null, properties);
configuration = (RepositoryConfiguration) createRepositoryConfigurationMethod.invoke(null, properties);
} catch (IllegalAccessException | NoSuchMethodException | InvocationTargetException e) {
e.printStackTrace();
}

View File

@ -57,6 +57,7 @@ import org.apache.nifi.provenance.serialization.StorageSummary;
import org.apache.nifi.provenance.store.ArrayListEventStore;
import org.apache.nifi.provenance.store.EventStore;
import org.apache.nifi.provenance.store.StorageResult;
import static org.junit.Assume.assumeFalse;
import org.junit.BeforeClass;
import org.junit.Rule;
import org.junit.Test;
@ -77,9 +78,13 @@ public class TestLuceneEventIndex {
System.setProperty("org.slf4j.simpleLogger.log.org.apache.nifi", "DEBUG");
}
private boolean isWindowsEnvironment() {
return System.getProperty("os.name").toLowerCase().startsWith("windows");
}
@Test(timeout = 5000)
public void testGetMinimumIdToReindex() throws InterruptedException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration repoConfig = createConfig(1);
repoConfig.setDesiredIndexSize(1L);
final IndexManager indexManager = new SimpleIndexManager(repoConfig);
@ -104,6 +109,7 @@ public class TestLuceneEventIndex {
@Test(timeout = 5000)
public void testUnauthorizedEventsGetPlaceholdersForLineage() throws InterruptedException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration repoConfig = createConfig(1);
repoConfig.setDesiredIndexSize(1L);
final IndexManager indexManager = new SimpleIndexManager(repoConfig);
@ -140,6 +146,7 @@ public class TestLuceneEventIndex {
@Test(timeout = 5000)
public void testUnauthorizedEventsGetPlaceholdersForExpandChildren() throws InterruptedException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration repoConfig = createConfig(1);
repoConfig.setDesiredIndexSize(1L);
final IndexManager indexManager = new SimpleIndexManager(repoConfig);
@ -215,6 +222,7 @@ public class TestLuceneEventIndex {
@Test(timeout = 5000)
public void testUnauthorizedEventsGetPlaceholdersForFindParents() throws InterruptedException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration repoConfig = createConfig(1);
repoConfig.setDesiredIndexSize(1L);
final IndexManager indexManager = new SimpleIndexManager(repoConfig);
@ -290,6 +298,7 @@ public class TestLuceneEventIndex {
@Test(timeout = 5000)
public void testUnauthorizedEventsGetFilteredForQuery() throws InterruptedException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration repoConfig = createConfig(1);
repoConfig.setDesiredIndexSize(1L);
final IndexManager indexManager = new SimpleIndexManager(repoConfig);
@ -398,6 +407,7 @@ public class TestLuceneEventIndex {
@Test(timeout = 5000)
public void addThenQueryWithEmptyQuery() throws InterruptedException {
assumeFalse(isWindowsEnvironment());
final RepositoryConfiguration repoConfig = createConfig();
final IndexManager indexManager = new SimpleIndexManager(repoConfig);

View File

@ -36,6 +36,7 @@ import org.junit.runner.RunWith;
import junitparams.JUnitParamsRunner;
import junitparams.Parameters;
import static org.junit.Assume.assumeFalse;
@RunWith(JUnitParamsRunner.class)
public class TransformersTest {
@ -127,16 +128,22 @@ public class TransformersTest {
"input_csv/primitive_types_with_matching_default.txt,input_avro/primitive_types_with_matching_default.txt,expected_ouput_csv/primitive_types_with_matching_default.txt",
"input_csv/decimal_logicalType_missing_value.txt,input_avro/decimal_logicalType_invalid_scale_with_default.txt,expected_ouput_csv/decimal_logicalType_with_default.txt"})
public void testCSVRoundtrip(final String inputCSVFileName, final String inputAvroSchema, final String expectedOuput) throws Exception {
assumeFalse(isWindowsEnvironment());
final String data = getResourceAsString(inputCSVFileName);
final String schemaText = getResourceAsString(inputAvroSchema);
final String result = getResourceAsString(expectedOuput);
csvRoundTrip(data, schemaText, result);
}
private boolean isWindowsEnvironment() {
return System.getProperty("os.name").toLowerCase().startsWith("windows");
}
@Test
@Parameters({"input_csv/union_with_missing_value.txt,input_avro/union_and_mismatch_defaults.txt",
"input_csv/primitive_types_with_matching_default.txt,input_avro/primitive_types_with_mismatch_default.txt"})
public void testCSVMismatchDefaults(final String inputCSVFileName, final String inputAvroSchema) {
assumeFalse(isWindowsEnvironment());
try {
final String data = getResourceAsString(inputCSVFileName);
final String schemaText = getResourceAsString(inputAvroSchema);
@ -153,6 +160,7 @@ public class TransformersTest {
@Test
public void testCSVRoundTrip() throws IOException {
assumeFalse(isWindowsEnvironment());
NumberFormat numberFormat = DecimalFormat.getInstance();
numberFormat.setGroupingUsed(false);
((DecimalFormat) numberFormat).setParseBigDecimal(true);

View File

@ -40,6 +40,7 @@ import java.util.List;
import java.util.Map;
import static org.junit.Assert.assertEquals;
import static org.junit.Assume.assumeFalse;
/**
@ -148,7 +149,7 @@ public class TestListDatabaseTables {
@Test
public void testListTablesAfterRefresh() throws Exception {
assumeFalse(isWindowsEnvironment());
// load test data to database
final Connection con = ((DBCPService) runner.getControllerService("dbcp")).getConnection();
Statement stmt = con.createStatement();
@ -185,6 +186,7 @@ public class TestListDatabaseTables {
@Test
public void testListTablesMultipleRefresh() throws Exception {
assumeFalse(isWindowsEnvironment());
// load test data to database
final Connection con = ((DBCPService) runner.getControllerService("dbcp")).getConnection();
@ -244,4 +246,9 @@ public class TestListDatabaseTables {
}
}
}
private boolean isWindowsEnvironment() {
return System.getProperty("os.name").toLowerCase().startsWith("windows");
}
}

View File

@ -43,6 +43,7 @@ import org.apache.nifi.util.TestRunner;
import org.apache.nifi.util.TestRunners;
import org.junit.After;
import org.junit.Assert;
import static org.junit.Assume.assumeFalse;
import org.junit.Before;
import org.junit.Test;
@ -836,9 +837,13 @@ public class TestTailFile {
runner.clearTransferState();
}
private boolean isWindowsEnvironment() {
return System.getProperty("os.name").toLowerCase().startsWith("windows");
}
@Test
public void testMigrateFrom100To110() throws IOException {
assumeFalse(isWindowsEnvironment());
runner.setProperty(TailFile.FILENAME, "target/existing-log.txt");
final MockStateManager stateManager = runner.getStateManager();
@ -886,6 +891,7 @@ public class TestTailFile {
@Test
public void testMigrateFrom100To110FileNotFound() throws IOException {
assumeFalse(isWindowsEnvironment());
runner.setProperty(TailFile.FILENAME, "target/not-existing-log.txt");

View File

@ -33,6 +33,7 @@ import static org.apache.nifi.processors.stateful.analysis.AttributeRollingWindo
import static org.apache.nifi.processors.stateful.analysis.AttributeRollingWindow.ROLLING_WINDOW_COUNT_KEY;
import static org.apache.nifi.processors.stateful.analysis.AttributeRollingWindow.ROLLING_WINDOW_MEAN_KEY;
import static org.apache.nifi.processors.stateful.analysis.AttributeRollingWindow.ROLLING_WINDOW_VALUE_KEY;
import static org.junit.Assume.assumeFalse;
public class TestAttributeRollingWindow {
@ -90,6 +91,9 @@ public class TestAttributeRollingWindow {
mockFlowFile.assertAttributeNotExists(ROLLING_WINDOW_MEAN_KEY);
}
private boolean isWindowsEnvironment() {
return System.getProperty("os.name").toLowerCase().startsWith("windows");
}
@Test
public void testBasic() throws InterruptedException {
@ -137,6 +141,7 @@ public class TestAttributeRollingWindow {
@Test
public void testVerifyCount() throws InterruptedException {
assumeFalse(isWindowsEnvironment());
final TestRunner runner = TestRunners.newTestRunner(AttributeRollingWindow.class);
runner.setProperty(AttributeRollingWindow.VALUE_TO_TRACK, "${value}");
@ -190,6 +195,7 @@ public class TestAttributeRollingWindow {
@Test
public void testMicroBatching() throws InterruptedException {
assumeFalse(isWindowsEnvironment());
final TestRunner runner = TestRunners.newTestRunner(AttributeRollingWindow.class);
runner.setProperty(AttributeRollingWindow.VALUE_TO_TRACK, "${value}");

View File

@ -33,6 +33,7 @@ import java.util.concurrent.atomic.AtomicReference;
import static org.junit.Assert.assertEquals;
import static org.junit.Assert.assertNotNull;
import static org.junit.Assert.assertTrue;
import static org.junit.Assume.assumeFalse;
import static org.mockito.Matchers.any;
import static org.mockito.Matchers.anyInt;
import static org.mockito.Matchers.anyString;
@ -102,9 +103,13 @@ public class TestJettyWebSocketCommunication {
protected interface MockWebSocketProcessor extends Processor, ConnectedListener, TextMessageConsumer, BinaryMessageConsumer {
}
private boolean isWindowsEnvironment() {
return System.getProperty("os.name").toLowerCase().startsWith("windows");
}
@Test
public void testClientServerCommunication() throws Exception {
assumeFalse(isWindowsEnvironment());
// Expectations.
final CountDownLatch serverIsConnectedByClient = new CountDownLatch(1);
final CountDownLatch clientConnectedServer = new CountDownLatch(1);

View File

@ -50,6 +50,7 @@ import static org.junit.Assert.assertNotEquals;
import static org.junit.Assert.assertNotNull;
import static org.junit.Assert.assertNull;
import static org.junit.Assert.fail;
import static org.junit.Assume.assumeFalse;
import static org.mockito.Matchers.any;
import static org.mockito.Mockito.doAnswer;
import static org.mockito.Mockito.mock;
@ -423,8 +424,13 @@ public class TlsToolkitStandaloneCommandLineTest {
tlsToolkitStandaloneCommandLine.parse("-n", "notInGlobalOrder", "-G", "nifi[1-3]");
}
private boolean isWindowsEnvironment() {
return System.getProperty("os.name").toLowerCase().startsWith("windows");
}
@Test
public void testDefaultOutputPathRoot() {
assumeFalse(isWindowsEnvironment());
Path root = Paths.get(".").toAbsolutePath().getRoot().resolve(".");
String calculateDefaultOutputDirectory = TlsToolkitStandaloneCommandLine.calculateDefaultOutputDirectory(root);
assertEquals(root.toAbsolutePath().getRoot().toString(), calculateDefaultOutputDirectory);