当前位置: 首页>>代码示例>>Java>>正文


Java TestUtils.tempDirectory方法代码示例

本文整理汇总了Java中org.apache.kafka.test.TestUtils.tempDirectory方法的典型用法代码示例。如果您正苦于以下问题:Java TestUtils.tempDirectory方法的具体用法?Java TestUtils.tempDirectory怎么用?Java TestUtils.tempDirectory使用的例子?那么恭喜您, 这里精选的方法代码示例或许可以为您提供帮助。您也可以进一步了解该方法所在org.apache.kafka.test.TestUtils的用法示例。


在下文中一共展示了TestUtils.tempDirectory方法的15个代码示例,这些例子默认根据受欢迎程度排序。您可以为喜欢或者感觉有用的代码点赞,您的评价将有助于系统推荐出更棒的Java代码示例。

示例1: shouldCreateLoggingEnabledStoreWhenWindowStoreLogged

import org.apache.kafka.test.TestUtils; //导入方法依赖的package包/类
@Test
public void shouldCreateLoggingEnabledStoreWhenWindowStoreLogged() throws Exception {
    store = createStore(true, false);
    final List<ProducerRecord> logged = new ArrayList<>();
    final NoOpRecordCollector collector = new NoOpRecordCollector() {
        @Override
        public <K, V> void send(final String topic,
                                K key,
                                V value,
                                Integer partition,
                                Long timestamp,
                                Serializer<K> keySerializer,
                                Serializer<V> valueSerializer) {
            logged.add(new ProducerRecord<K, V>(topic, partition, timestamp, key, value));
        }
    };
    final MockProcessorContext context = new MockProcessorContext(TestUtils.tempDirectory(),
                                                                  Serdes.String(),
                                                                  Serdes.String(),
                                                                  collector,
                                                                  cache);
    context.setTime(1);
    store.init(context, store);
    store.put("a", "b");
    assertFalse(logged.isEmpty());
}
 
开发者ID:YMCoding,项目名称:kafka-0.11.0.0-src-with-comment,代码行数:27,代码来源:RocksDBWindowStoreSupplierTest.java

示例2: before

import org.apache.kafka.test.TestUtils; //导入方法依赖的package包/类
@Before
public void before() {
    final NoOpRecordCollector collector = new NoOpRecordCollector() {
        @Override
        public <K, V> void send(final String topic,
                                K key,
                                V value,
                                Integer partition,
                                Long timestamp,
                                Serializer<K> keySerializer,
                                Serializer<V> valueSerializer) {
            sent.put(key, value);
        }
    };
    context = new MockProcessorContext(
        TestUtils.tempDirectory(),
        Serdes.String(),
        Serdes.Long(),
        collector,
        new ThreadCache("testCache", 0, new MockStreamsMetrics(new Metrics())));
    context.setTime(0);
    store.init(context, store);
}
 
开发者ID:YMCoding,项目名称:kafka-0.11.0.0-src-with-comment,代码行数:24,代码来源:ChangeLoggingKeyValueStoreTest.java

示例3: setup

import org.apache.kafka.test.TestUtils; //导入方法依赖的package包/类
@Before
public void setup() {
    restoreStateConsumer.reset();
    restoreStateConsumer.updatePartitions(storeChangelogTopicName1, Utils.mkList(
            new PartitionInfo(storeChangelogTopicName1, 0, Node.noNode(), new Node[0], new Node[0]),
            new PartitionInfo(storeChangelogTopicName1, 1, Node.noNode(), new Node[0], new Node[0]),
            new PartitionInfo(storeChangelogTopicName1, 2, Node.noNode(), new Node[0], new Node[0])
    ));

    restoreStateConsumer.updatePartitions(storeChangelogTopicName2, Utils.mkList(
            new PartitionInfo(storeChangelogTopicName2, 0, Node.noNode(), new Node[0], new Node[0]),
            new PartitionInfo(storeChangelogTopicName2, 1, Node.noNode(), new Node[0], new Node[0]),
            new PartitionInfo(storeChangelogTopicName2, 2, Node.noNode(), new Node[0], new Node[0])
    ));
    baseDir = TestUtils.tempDirectory();
    stateDirectory = new StateDirectory(applicationId, baseDir.getPath(), new MockTime());
}
 
开发者ID:YMCoding,项目名称:kafka-0.11.0.0-src-with-comment,代码行数:18,代码来源:StandbyTaskTest.java

示例4: shouldNotBeLoggingEnabledStoreWhenLoggingNotEnabled

import org.apache.kafka.test.TestUtils; //导入方法依赖的package包/类
@Test
public void shouldNotBeLoggingEnabledStoreWhenLoggingNotEnabled() throws Exception {
    store = createStore(false, false);
    final List<ProducerRecord> logged = new ArrayList<>();
    final NoOpRecordCollector collector = new NoOpRecordCollector() {
        @Override
        public <K, V> void send(final String topic,
                                K key,
                                V value,
                                Integer partition,
                                Long timestamp,
                                Serializer<K> keySerializer,
                                Serializer<V> valueSerializer) {
            logged.add(new ProducerRecord<K, V>(topic, partition, timestamp, key, value));
        }
    };
    final MockProcessorContext context = new MockProcessorContext(TestUtils.tempDirectory(),
                                                                  Serdes.String(),
                                                                  Serdes.String(),
                                                                  collector,
                                                                  cache);
    context.setTime(1);
    store.init(context, store);
    store.put("a", "b");
    assertTrue(logged.isEmpty());
}
 
开发者ID:YMCoding,项目名称:kafka-0.11.0.0-src-with-comment,代码行数:27,代码来源:RocksDBKeyValueStoreSupplierTest.java

示例5: shouldNotBeLoggingEnabledStoreWhenLogginNotEnabled

import org.apache.kafka.test.TestUtils; //导入方法依赖的package包/类
@Test
public void shouldNotBeLoggingEnabledStoreWhenLogginNotEnabled() throws Exception {
    store = createStore(false, false);
    final List<ProducerRecord> logged = new ArrayList<>();
    final NoOpRecordCollector collector = new NoOpRecordCollector() {
        @Override
        public <K, V> void send(final String topic,
                                K key,
                                V value,
                                Integer partition,
                                Long timestamp,
                                Serializer<K> keySerializer,
                                Serializer<V> valueSerializer) {
            logged.add(new ProducerRecord<K, V>(topic, partition, timestamp, key, value));
        }
    };
    final MockProcessorContext context = new MockProcessorContext(TestUtils.tempDirectory(),
                                                                  Serdes.String(),
                                                                  Serdes.String(),
                                                                  collector,
                                                                  cache);
    context.setTime(1);
    store.init(context, store);
    store.put("a", "b");
    assertTrue(logged.isEmpty());
}
 
开发者ID:YMCoding,项目名称:kafka-0.11.0.0-src-with-comment,代码行数:27,代码来源:RocksDBWindowStoreSupplierTest.java

示例6: doAggregateSessionWindows

import org.apache.kafka.test.TestUtils; //导入方法依赖的package包/类
private void doAggregateSessionWindows(final Map<Windowed<String>, Integer> results) throws Exception {
    driver = new KStreamTestDriver(builder, TestUtils.tempDirectory());
    driver.setTime(10);
    driver.process(TOPIC, "1", "1");
    driver.setTime(15);
    driver.process(TOPIC, "2", "2");
    driver.setTime(30);
    driver.process(TOPIC, "1", "1");
    driver.setTime(70);
    driver.process(TOPIC, "1", "1");
    driver.setTime(90);
    driver.process(TOPIC, "1", "1");
    driver.setTime(100);
    driver.process(TOPIC, "1", "1");
    driver.flushState();
    assertEquals(Integer.valueOf(2), results.get(new Windowed<>("1", new SessionWindow(10, 30))));
    assertEquals(Integer.valueOf(1), results.get(new Windowed<>("2", new SessionWindow(15, 15))));
    assertEquals(Integer.valueOf(3), results.get(new Windowed<>("1", new SessionWindow(70, 100))));
}
 
开发者ID:YMCoding,项目名称:kafka-0.11.0.0-src-with-comment,代码行数:20,代码来源:KGroupedStreamImplTest.java

示例7: doCountSessionWindows

import org.apache.kafka.test.TestUtils; //导入方法依赖的package包/类
private void doCountSessionWindows(final Map<Windowed<String>, Long> results) throws Exception {
    driver = new KStreamTestDriver(builder, TestUtils.tempDirectory());
    driver.setTime(10);
    driver.process(TOPIC, "1", "1");
    driver.setTime(15);
    driver.process(TOPIC, "2", "2");
    driver.setTime(30);
    driver.process(TOPIC, "1", "1");
    driver.setTime(70);
    driver.process(TOPIC, "1", "1");
    driver.setTime(90);
    driver.process(TOPIC, "1", "1");
    driver.setTime(100);
    driver.process(TOPIC, "1", "1");
    driver.flushState();
    assertEquals(Long.valueOf(2), results.get(new Windowed<>("1", new SessionWindow(10, 30))));
    assertEquals(Long.valueOf(1), results.get(new Windowed<>("2", new SessionWindow(15, 15))));
    assertEquals(Long.valueOf(3), results.get(new Windowed<>("1", new SessionWindow(70, 100))));
}
 
开发者ID:YMCoding,项目名称:kafka-0.11.0.0-src-with-comment,代码行数:20,代码来源:KGroupedStreamImplTest.java

示例8: before

import org.apache.kafka.test.TestUtils; //导入方法依赖的package包/类
@Before
public void before() {
    final SessionKeySchema schema = new SessionKeySchema();
    schema.init("topic");

    final RocksDBSegmentedBytesStore bytesStore =
            new RocksDBSegmentedBytesStore("session-store", 10000L, 3, schema);

    sessionStore = new RocksDBSessionStore<>(bytesStore,
                                             Serdes.String(),
                                             Serdes.Long());

    context = new MockProcessorContext(TestUtils.tempDirectory(),
                                       Serdes.String(),
                                       Serdes.Long(),
                                       new NoOpRecordCollector(),
                                       new ThreadCache("testCache", 0, new MockStreamsMetrics(new Metrics())));
    sessionStore.init(context, sessionStore);
}
 
开发者ID:YMCoding,项目名称:kafka-0.11.0.0-src-with-comment,代码行数:20,代码来源:RocksDBSessionStoreTest.java

示例9: setUp

import org.apache.kafka.test.TestUtils; //导入方法依赖的package包/类
@Before
public void setUp() throws Exception {
    keySchema = new WindowKeySchema();
    final int retention = 30000;
    final int numSegments = 3;
    underlying = new RocksDBSegmentedBytesStore("test", retention, numSegments, keySchema);
    final RocksDBWindowStore<Bytes, byte[]> windowStore = new RocksDBWindowStore<>(underlying, Serdes.Bytes(), Serdes.ByteArray(), false, WINDOW_SIZE);
    cacheListener = new CachingKeyValueStoreTest.CacheFlushListenerStub<>();
    cachingStore = new CachingWindowStore<>(windowStore,
                                            Serdes.String(),
                                            Serdes.String(),
                                            WINDOW_SIZE,
                                            Segments.segmentInterval(retention, numSegments));
    cachingStore.setFlushListener(cacheListener);
    cache = new ThreadCache("testCache", MAX_CACHE_SIZE_BYTES, new MockStreamsMetrics(new Metrics()));
    topic = "topic";
    context = new MockProcessorContext(TestUtils.tempDirectory(), null, null, (RecordCollector) null, cache);
    context.setRecordContext(new ProcessorRecordContext(DEFAULT_TIMESTAMP, 0, 0, topic));
    cachingStore.init(context, cachingStore);
}
 
开发者ID:YMCoding,项目名称:kafka-0.11.0.0-src-with-comment,代码行数:21,代码来源:CachingWindowStoreTest.java

示例10: setUp

import org.apache.kafka.test.TestUtils; //导入方法依赖的package包/类
@Before
public void setUp() throws Exception {
    final SessionKeySchema schema = new SessionKeySchema();
    schema.init("topic");
    final int retention = 60000;
    final int numSegments = 3;
    underlying = new RocksDBSegmentedBytesStore("test", retention, numSegments, schema);
    final RocksDBSessionStore<Bytes, byte[]> sessionStore = new RocksDBSessionStore<>(underlying, Serdes.Bytes(), Serdes.ByteArray());
    cachingStore = new CachingSessionStore<>(sessionStore,
                                             Serdes.String(),
                                             Serdes.Long(),
                                             Segments.segmentInterval(retention, numSegments)
                                             );
    cache = new ThreadCache("testCache", MAX_CACHE_SIZE_BYTES, new MockStreamsMetrics(new Metrics()));
    context = new MockProcessorContext(TestUtils.tempDirectory(), null, null, (RecordCollector) null, cache);
    context.setRecordContext(new ProcessorRecordContext(DEFAULT_TIMESTAMP, 0, 0, "topic"));
    cachingStore.init(context, cachingStore);
}
 
开发者ID:YMCoding,项目名称:kafka-0.11.0.0-src-with-comment,代码行数:19,代码来源:CachingSessionStoreTest.java

示例11: shouldListAllTaskDirectories

import org.apache.kafka.test.TestUtils; //导入方法依赖的package包/类
@Test
public void shouldListAllTaskDirectories() throws Exception {
    TestUtils.tempDirectory(stateDir.toPath(), "foo");
    final File taskDir1 = directory.directoryForTask(new TaskId(0, 0));
    final File taskDir2 = directory.directoryForTask(new TaskId(0, 1));

    final List<File> dirs = Arrays.asList(directory.listTaskDirectories());
    assertEquals(2, dirs.size());
    assertTrue(dirs.contains(taskDir1));
    assertTrue(dirs.contains(taskDir2));
}
 
开发者ID:YMCoding,项目名称:kafka-0.11.0.0-src-with-comment,代码行数:12,代码来源:StateDirectoryTest.java

示例12: initializeStore

import org.apache.kafka.test.TestUtils; //导入方法依赖的package包/类
@SuppressWarnings("unchecked")
@Before
public void initializeStore() {
    final File stateDir = TestUtils.tempDirectory();
    context = new MockProcessorContext(stateDir,
        Serdes.String(), Serdes.String(), new NoOpRecordCollector(), new ThreadCache("testCache", 100000, new MockStreamsMetrics(new Metrics()))) {
        @Override
        public <K, V> void forward(final K key, final V value) {
            results.add(KeyValue.pair(key, value));
        }
    };

    initStore(true);
    processor.init(context);
}
 
开发者ID:YMCoding,项目名称:kafka-0.11.0.0-src-with-comment,代码行数:16,代码来源:KStreamSessionWindowAggregateProcessorTest.java

示例13: shouldCreateDirectoriesIfParentDoesntExist

import org.apache.kafka.test.TestUtils; //导入方法依赖的package包/类
@Test
public void shouldCreateDirectoriesIfParentDoesntExist() throws Exception {
    final File tempDir = TestUtils.tempDirectory();
    final File stateDir = new File(new File(tempDir, "foo"), "state-dir");
    final StateDirectory stateDirectory = new StateDirectory(applicationId, stateDir.getPath(), time);
    final File taskDir = stateDirectory.directoryForTask(new TaskId(0, 0));
    assertTrue(stateDir.exists());
    assertTrue(taskDir.exists());
}
 
开发者ID:YMCoding,项目名称:kafka-0.11.0.0-src-with-comment,代码行数:10,代码来源:StateDirectoryTest.java

示例14: setup

import org.apache.kafka.test.TestUtils; //导入方法依赖的package包/类
@Before
public void setup() {
    baseDir = TestUtils.tempDirectory();
    stateDirectory = new StateDirectory(applicationId, baseDir.getPath(), new MockTime());
    checkpointFile = new File(stateDirectory.directoryForTask(taskId), ProcessorStateManager.CHECKPOINT_FILE_NAME);
    checkpoint = new OffsetCheckpoint(checkpointFile);
}
 
开发者ID:YMCoding,项目名称:kafka-0.11.0.0-src-with-comment,代码行数:8,代码来源:ProcessorStateManagerTest.java

示例15: setUp

import org.apache.kafka.test.TestUtils; //导入方法依赖的package包/类
@Before
public void setUp() throws IOException {
    stateDir = TestUtils.tempDirectory("kafka-test");
}
 
开发者ID:YMCoding,项目名称:kafka-0.11.0.0-src-with-comment,代码行数:5,代码来源:KTableFilterTest.java


注:本文中的org.apache.kafka.test.TestUtils.tempDirectory方法示例由纯净天空整理自Github/MSDocs等开源代码及文档管理平台,相关代码片段筛选自各路编程大神贡献的开源项目,源码版权归原作者所有,传播和使用请参考对应项目的License;未经允许,请勿转载。