Class SerializableMatchers
- All Implemented Interfaces:
Serializable
SerializableMatcher
instances.
Most matchers are wrappers for hamcrest's Matchers
. Please be familiar with the
documentation there. Values retained by a SerializableMatcher
are required to be
serializable, either via Java serialization or via a provided Coder
.
The following matchers are novel to Apache Beam:
kvWithKey(K)
for matching just the key of aKV
.kvWithValue(V)
for matching just the value of aKV
.kv(org.apache.beam.sdk.testing.SerializableMatcher<? super K>, org.apache.beam.sdk.testing.SerializableMatcher<? super V>)
for matching the key and value of aKV
.
For example, to match a group from GroupByKey
, which
has type KV<K, Iterable<V>>
for some K
and V
and where the order of the
iterable is undefined, use a matcher like kv(equalTo("some key"), containsInAnyOrder(1, 2,
3))
.
- See Also:
-
Method Summary
Modifier and TypeMethodDescriptionstatic <T> SerializableMatcher
<T> allOf
(Iterable<SerializableMatcher<? super T>> serializableMatchers) ASerializableMatcher
with identical criteria toMatchers.allOf(Iterable)
.static <T> SerializableMatcher
<T> allOf
(SerializableMatcher<T>... matchers) ASerializableMatcher
with identical criteria toMatchers.allOf(Matcher[])
.static <T> SerializableMatcher
<T> anyOf
(Iterable<SerializableMatcher<? super T>> serializableMatchers) ASerializableMatcher
with identical criteria toMatchers.anyOf(Iterable)
.static <T> SerializableMatcher
<T> anyOf
(SerializableMatcher<T>... matchers) ASerializableMatcher
with identical criteria toMatchers.anyOf(Matcher[])
.static SerializableMatcher
<Object> anything()
ASerializableMatcher
with identical criteria toMatchers.anything()
.static <T> SerializableMatcher
<T[]> arrayContaining
(List<SerializableMatcher<? super T>> serializableMatchers) ASerializableMatcher
with identical criteria toMatchers.arrayContaining(List)
.static <T> SerializableMatcher
<T[]> arrayContaining
(Coder<T> coder, T... items) ASerializableMatcher
with identical criteria toMatchers.arrayContaining(Object[])
.static <T> SerializableMatcher
<T[]> arrayContaining
(SerializableMatcher<? super T>... matchers) ASerializableMatcher
with identical criteria toMatchers.arrayContaining(Matcher[])
.static <T extends Serializable>
SerializableMatcher<T[]> arrayContaining
(T... items) ASerializableMatcher
with identical criteria toMatchers.arrayContaining(Object[])
.static <T> SerializableMatcher
<T[]> arrayContainingInAnyOrder
(Collection<SerializableMatcher<? super T>> serializableMatchers) ASerializableMatcher
with identical criteria toMatchers.arrayContainingInAnyOrder(Collection)
.static <T> SerializableMatcher
<T[]> arrayContainingInAnyOrder
(Coder<T> coder, T... items) ASerializableMatcher
with identical criteria toMatchers.arrayContainingInAnyOrder(Object[])
.static <T> SerializableMatcher
<T[]> arrayContainingInAnyOrder
(SerializableMatcher<? super T>... matchers) ASerializableMatcher
with identical criteria toMatchers.arrayContainingInAnyOrder(Matcher[])
.static <T extends Serializable>
SerializableMatcher<T[]> arrayContainingInAnyOrder
(T... items) ASerializableMatcher
with identical criteria toMatchers.arrayContainingInAnyOrder(Object[])
.static <T> SerializableMatcher
<T[]> arrayWithSize
(int size) ASerializableMatcher
with identical criteria toMatchers.arrayWithSize(int)
.static <T> SerializableMatcher
<T[]> arrayWithSize
(SerializableMatcher<? super Integer> sizeMatcher) ASerializableMatcher
with identical criteria toMatchers.arrayWithSize(Matcher)
.static SerializableMatcher
<Double> closeTo
(double target, double error) ASerializableMatcher
with identical criteria toMatchers.closeTo(double,double)
.static <T extends Serializable>
SerializableMatcher<Iterable<? extends T>> contains
(List<SerializableMatcher<? super T>> serializableMatchers) ASerializableMatcher
with identical criteria toMatchers.contains(List)
.static <T> SerializableMatcher
<Iterable<? extends T>> ASerializableMatcher
with identical criteria toMatchers.contains(Object[])
.static <T> SerializableMatcher
<Iterable<? extends T>> contains
(SerializableMatcher<? super T>... matchers) ASerializableMatcher
with identical criteria toMatchers.contains(Matcher[])
.static <T extends Serializable>
SerializableMatcher<Iterable<? extends T>> contains
(T... items) ASerializableMatcher
with identical criteria toMatchers.contains(Object[])
.static <T> SerializableMatcher
<Iterable<? extends T>> containsInAnyOrder
(Collection<SerializableMatcher<? super T>> serializableMatchers) ASerializableMatcher
with identical criteria toMatchers.containsInAnyOrder(Collection)
.static <T> SerializableMatcher
<Iterable<? extends T>> containsInAnyOrder
(Coder<T> coder, T... items) ASerializableMatcher
with identical criteria toMatchers.containsInAnyOrder(Object[])
.static <T> SerializableMatcher
<Iterable<? extends T>> containsInAnyOrder
(SerializableMatcher<? super T>... matchers) ASerializableMatcher
with identical criteria toMatchers.containsInAnyOrder(Matcher[])
.static <T extends Serializable>
SerializableMatcher<Iterable<? extends T>> containsInAnyOrder
(T... items) ASerializableMatcher
with identical criteria toMatchers.containsInAnyOrder(Object[])
.static SerializableMatcher
<String> containsString
(String substring) ASerializableMatcher
with identical criteria toMatchers.containsString(java.lang.String)
.static <T> SerializableMatcher
<Collection<? extends T>> empty()
ASerializableMatcher
with identical criteria toMatchers.empty()
.static <T> SerializableMatcher
<T[]> ASerializableMatcher
with identical criteria toMatchers.emptyArray()
.static <T> SerializableMatcher
<Iterable<? extends T>> ASerializableMatcher
with identical criteria toMatchers.emptyIterable()
.static SerializableMatcher
<String> ASerializableMatcher
with identical criteria toMatchers.endsWith(java.lang.String)
.static <T> SerializableMatcher
<T> ASerializableMatcher
with identical criteria toMatchers.equalTo(Object)
.static <T extends Serializable>
SerializableMatcher<T> equalTo
(T expected) ASerializableMatcher
with identical criteria toMatchers.equalTo(Object)
.static <T> SerializableMatcher
<T> fromSupplier
(org.apache.beam.sdk.util.SerializableSupplier<Matcher<T>> supplier) Constructs aSerializableMatcher
from a non-serializableMatcher
via indirection throughSerializableSupplier
.static <T extends Comparable<T> & Serializable>
SerializableMatcher<T> greaterThan
(Coder<T> coder, T target) ASerializableMatcher
with identical criteria toMatchers.greaterThan(Comparable)
.static <T extends Comparable<T> & Serializable>
SerializableMatcher<T> greaterThan
(T target) ASerializableMatcher
with identical criteria toMatchers.greaterThan(Comparable)
.static <T extends Comparable<T> & Serializable>
SerializableMatcher<T> greaterThanOrEqualTo
(Coder<T> coder, T target) ASerializableMatcher
with identical criteria toMatchers.greaterThanOrEqualTo(Comparable)
.static <T extends Comparable<T>>
SerializableMatcher<T> greaterThanOrEqualTo
(T target) ASerializableMatcher
with identical criteria toMatchers.greaterThanOrEqualTo(Comparable)
.static <T> SerializableMatcher
<Iterable<? super T>> ASerializableMatcher
with identical criteria toMatchers.hasItem(Object)
.static <T> SerializableMatcher
<Iterable<? super T>> hasItem
(SerializableMatcher<? super T> matcher) ASerializableMatcher
with identical criteria toMatchers.hasItem(Matcher)
.static <T extends Serializable>
SerializableMatcher<Iterable<? super T>> hasItem
(T target) ASerializableMatcher
with identical criteria toMatchers.hasItem(Object)
.static <T> SerializableMatcher
<Collection<? extends T>> hasSize
(int size) ASerializableMatcher
with identical criteria toMatchers.hasSize(int)
.static <T> SerializableMatcher
<Collection<? extends T>> hasSize
(SerializableMatcher<? super Integer> sizeMatcher) ASerializableMatcher
with identical criteria toMatchers.hasSize(Matcher)
.static <T extends Serializable>
SerializableMatcher<T> isIn
(Collection<T> collection) ASerializableMatcher
with identical criteria toMatchers.isIn(Collection)
.static <T> SerializableMatcher
<T> isIn
(Coder<T> coder, Collection<T> collection) ASerializableMatcher
with identical criteria toMatchers.isIn(Collection)
.static <T> SerializableMatcher
<T> ASerializableMatcher
with identical criteria toMatchers.isIn(Object[])
.static <T extends Serializable>
SerializableMatcher<T> isIn
(T[] items) ASerializableMatcher
with identical criteria toMatchers.isIn(Object[])
.static <T> SerializableMatcher
<T> ASerializableMatcher
with identical criteria toMatchers.isOneOf(T...)
.static <T extends Serializable>
SerializableMatcher<T> isOneOf
(T... elems) ASerializableMatcher
with identical criteria toMatchers.isOneOf(T...)
.static <T> SerializableMatcher
<Iterable<T>> iterableWithSize
(int size) ASerializableMatcher
with identical criteria toMatchers.iterableWithSize(int)
.static <T> SerializableMatcher
<Iterable<T>> iterableWithSize
(SerializableMatcher<? super Integer> sizeMatcher) ASerializableMatcher
with identical criteria toMatchers.iterableWithSize(Matcher)
.static <K,
V> SerializableMatcher <KV<? extends K, ? extends V>> kv
(SerializableMatcher<? super K> keyMatcher, SerializableMatcher<? super V> valueMatcher) ASerializableMatcher
that matches anyKV
with matching key and value.static <K extends Serializable,
V>
SerializableMatcher<KV<? extends K, ? extends V>> kvWithKey
(K key) ASerializableMatcher
that matches anyKV
with the specified key.static <K,
V> SerializableMatcher <KV<? extends K, ? extends V>> ASerializableMatcher
that matches anyKV
with the specified key.static <K,
V> SerializableMatcher <KV<? extends K, ? extends V>> kvWithKey
(SerializableMatcher<? super K> keyMatcher) ASerializableMatcher
that matches anyKV
with matching key.static <K,
V> SerializableMatcher <KV<? extends K, ? extends V>> kvWithValue
(Coder<V> coder, V value) ASerializableMatcher
that matches anyKV
with the specified value.static <K,
V> SerializableMatcher <KV<? extends K, ? extends V>> kvWithValue
(SerializableMatcher<? super V> valueMatcher) ASerializableMatcher
that matches anyKV
with matching value.static <K,
V extends Serializable>
SerializableMatcher<KV<? extends K, ? extends V>> kvWithValue
(V value) ASerializableMatcher
that matches anyKV
with the specified value.static <T extends Comparable<T>>
SerializableMatcher<T> ASerializableMatcher
with identical criteria toMatchers.lessThan(Comparable)
.static <T extends Comparable<T> & Serializable>
SerializableMatcher<T> lessThan
(T target) ASerializableMatcher
with identical criteria toMatchers.lessThan(Comparable)
.static <T extends Comparable<T>>
SerializableMatcher<T> lessThanOrEqualTo
(Coder<T> coder, T target) ASerializableMatcher
with identical criteria toMatchers.lessThanOrEqualTo(Comparable)
.static <T extends Comparable<T> & Serializable>
SerializableMatcher<T> lessThanOrEqualTo
(T target) ASerializableMatcher
with identical criteria toMatchers.lessThanOrEqualTo(Comparable)
.static <T> SerializableMatcher
<T> not
(SerializableMatcher<T> matcher) ASerializableMatcher
with identical criteria toMatchers.not(org.hamcrest.Matcher<T>)
.static SerializableMatcher
<Object> ASerializableMatcher
with identical criteria toMatchers.nullValue()
.static SerializableMatcher
<String> startsWith
(String substring) ASerializableMatcher
with identical criteria toMatchers.startsWith(java.lang.String)
.
-
Method Details
-
allOf
public static <T> SerializableMatcher<T> allOf(Iterable<SerializableMatcher<? super T>> serializableMatchers) ASerializableMatcher
with identical criteria toMatchers.allOf(Iterable)
. -
allOf
ASerializableMatcher
with identical criteria toMatchers.allOf(Matcher[])
. -
anyOf
public static <T> SerializableMatcher<T> anyOf(Iterable<SerializableMatcher<? super T>> serializableMatchers) ASerializableMatcher
with identical criteria toMatchers.anyOf(Iterable)
. -
anyOf
ASerializableMatcher
with identical criteria toMatchers.anyOf(Matcher[])
. -
anything
ASerializableMatcher
with identical criteria toMatchers.anything()
. -
arrayContaining
@SafeVarargs public static <T extends Serializable> SerializableMatcher<T[]> arrayContaining(T... items) ASerializableMatcher
with identical criteria toMatchers.arrayContaining(Object[])
. -
arrayContaining
ASerializableMatcher
with identical criteria toMatchers.arrayContaining(Object[])
.The items of type
T
will be serialized using the providedCoder
. They are explicitly not required or expected to be serializable via Java serialization. -
arrayContaining
@SafeVarargs public static <T> SerializableMatcher<T[]> arrayContaining(SerializableMatcher<? super T>... matchers) ASerializableMatcher
with identical criteria toMatchers.arrayContaining(Matcher[])
. -
arrayContaining
public static <T> SerializableMatcher<T[]> arrayContaining(List<SerializableMatcher<? super T>> serializableMatchers) ASerializableMatcher
with identical criteria toMatchers.arrayContaining(List)
. -
arrayContainingInAnyOrder
@SafeVarargs public static <T extends Serializable> SerializableMatcher<T[]> arrayContainingInAnyOrder(T... items) ASerializableMatcher
with identical criteria toMatchers.arrayContainingInAnyOrder(Object[])
. -
arrayContainingInAnyOrder
@SafeVarargs public static <T> SerializableMatcher<T[]> arrayContainingInAnyOrder(Coder<T> coder, T... items) ASerializableMatcher
with identical criteria toMatchers.arrayContainingInAnyOrder(Object[])
.The items of type
T
will be serialized using the providedCoder
. They are explicitly not required or expected to be serializable via Java serialization. -
arrayContainingInAnyOrder
@SafeVarargs public static <T> SerializableMatcher<T[]> arrayContainingInAnyOrder(SerializableMatcher<? super T>... matchers) ASerializableMatcher
with identical criteria toMatchers.arrayContainingInAnyOrder(Matcher[])
. -
arrayContainingInAnyOrder
public static <T> SerializableMatcher<T[]> arrayContainingInAnyOrder(Collection<SerializableMatcher<? super T>> serializableMatchers) ASerializableMatcher
with identical criteria toMatchers.arrayContainingInAnyOrder(Collection)
. -
arrayWithSize
ASerializableMatcher
with identical criteria toMatchers.arrayWithSize(int)
. -
arrayWithSize
public static <T> SerializableMatcher<T[]> arrayWithSize(SerializableMatcher<? super Integer> sizeMatcher) ASerializableMatcher
with identical criteria toMatchers.arrayWithSize(Matcher)
. -
closeTo
ASerializableMatcher
with identical criteria toMatchers.closeTo(double,double)
. -
contains
@SafeVarargs public static <T extends Serializable> SerializableMatcher<Iterable<? extends T>> contains(T... items) ASerializableMatcher
with identical criteria toMatchers.contains(Object[])
. -
contains
@SafeVarargs public static <T> SerializableMatcher<Iterable<? extends T>> contains(Coder<T> coder, T... items) ASerializableMatcher
with identical criteria toMatchers.contains(Object[])
.The items of type
T
will be serialized using the providedCoder
. They are explicitly not required or expected to be serializable via Java serialization. -
contains
@SafeVarargs public static <T> SerializableMatcher<Iterable<? extends T>> contains(SerializableMatcher<? super T>... matchers) ASerializableMatcher
with identical criteria toMatchers.contains(Matcher[])
. -
contains
public static <T extends Serializable> SerializableMatcher<Iterable<? extends T>> contains(List<SerializableMatcher<? super T>> serializableMatchers) ASerializableMatcher
with identical criteria toMatchers.contains(List)
. -
containsInAnyOrder
@SafeVarargs public static <T extends Serializable> SerializableMatcher<Iterable<? extends T>> containsInAnyOrder(T... items) ASerializableMatcher
with identical criteria toMatchers.containsInAnyOrder(Object[])
. -
containsInAnyOrder
@SafeVarargs public static <T> SerializableMatcher<Iterable<? extends T>> containsInAnyOrder(Coder<T> coder, T... items) ASerializableMatcher
with identical criteria toMatchers.containsInAnyOrder(Object[])
.The items of type
T
will be serialized using the providedCoder
. It is explicitly not required or expected to be serializable via Java serialization. -
containsInAnyOrder
@SafeVarargs public static <T> SerializableMatcher<Iterable<? extends T>> containsInAnyOrder(SerializableMatcher<? super T>... matchers) ASerializableMatcher
with identical criteria toMatchers.containsInAnyOrder(Matcher[])
. -
containsInAnyOrder
public static <T> SerializableMatcher<Iterable<? extends T>> containsInAnyOrder(Collection<SerializableMatcher<? super T>> serializableMatchers) ASerializableMatcher
with identical criteria toMatchers.containsInAnyOrder(Collection)
. -
containsString
ASerializableMatcher
with identical criteria toMatchers.containsString(java.lang.String)
. -
empty
ASerializableMatcher
with identical criteria toMatchers.empty()
. -
emptyArray
ASerializableMatcher
with identical criteria toMatchers.emptyArray()
. -
emptyIterable
ASerializableMatcher
with identical criteria toMatchers.emptyIterable()
. -
endsWith
ASerializableMatcher
with identical criteria toMatchers.endsWith(java.lang.String)
. -
equalTo
ASerializableMatcher
with identical criteria toMatchers.equalTo(Object)
. -
equalTo
ASerializableMatcher
with identical criteria toMatchers.equalTo(Object)
.The expected value of type
T
will be serialized using the providedCoder
. It is explicitly not required or expected to be serializable via Java serialization. -
greaterThan
ASerializableMatcher
with identical criteria toMatchers.greaterThan(Comparable)
. -
greaterThan
public static <T extends Comparable<T> & Serializable> SerializableMatcher<T> greaterThan(Coder<T> coder, T target) ASerializableMatcher
with identical criteria toMatchers.greaterThan(Comparable)
.The target value of type
T
will be serialized using the providedCoder
. It is explicitly not required or expected to be serializable via Java serialization. -
greaterThanOrEqualTo
ASerializableMatcher
with identical criteria toMatchers.greaterThanOrEqualTo(Comparable)
. -
greaterThanOrEqualTo
public static <T extends Comparable<T> & Serializable> SerializableMatcher<T> greaterThanOrEqualTo(Coder<T> coder, T target) ASerializableMatcher
with identical criteria toMatchers.greaterThanOrEqualTo(Comparable)
.The target value of type
T
will be serialized using the providedCoder
. It is explicitly not required or expected to be serializable via Java serialization. -
hasItem
ASerializableMatcher
with identical criteria toMatchers.hasItem(Object)
. -
hasItem
ASerializableMatcher
with identical criteria toMatchers.hasItem(Object)
.The item of type
T
will be serialized using the providedCoder
. It is explicitly not required or expected to be serializable via Java serialization. -
hasItem
public static <T> SerializableMatcher<Iterable<? super T>> hasItem(SerializableMatcher<? super T> matcher) ASerializableMatcher
with identical criteria toMatchers.hasItem(Matcher)
. -
hasSize
ASerializableMatcher
with identical criteria toMatchers.hasSize(int)
. -
hasSize
public static <T> SerializableMatcher<Collection<? extends T>> hasSize(SerializableMatcher<? super Integer> sizeMatcher) ASerializableMatcher
with identical criteria toMatchers.hasSize(Matcher)
. -
iterableWithSize
ASerializableMatcher
with identical criteria toMatchers.iterableWithSize(int)
. -
iterableWithSize
public static <T> SerializableMatcher<Iterable<T>> iterableWithSize(SerializableMatcher<? super Integer> sizeMatcher) ASerializableMatcher
with identical criteria toMatchers.iterableWithSize(Matcher)
. -
isIn
ASerializableMatcher
with identical criteria toMatchers.isIn(Collection)
. -
isIn
ASerializableMatcher
with identical criteria toMatchers.isIn(Collection)
.The items of type
T
will be serialized using the providedCoder
. They are explicitly not required or expected to be serializable via Java serialization. -
isIn
ASerializableMatcher
with identical criteria toMatchers.isIn(Object[])
. -
isIn
ASerializableMatcher
with identical criteria toMatchers.isIn(Object[])
.The items of type
T
will be serialized using the providedCoder
. They are explicitly not required or expected to be serializable via Java serialization. -
isOneOf
ASerializableMatcher
with identical criteria toMatchers.isOneOf(T...)
. -
isOneOf
ASerializableMatcher
with identical criteria toMatchers.isOneOf(T...)
.The items of type
T
will be serialized using the providedCoder
. They are explicitly not required or expected to be serializable via Java serialization. -
kvWithKey
public static <K extends Serializable,V> SerializableMatcher<KV<? extends K,? extends V>> kvWithKey(K key) ASerializableMatcher
that matches anyKV
with the specified key. -
kvWithKey
public static <K,V> SerializableMatcher<KV<? extends K,? extends V>> kvWithKey(Coder<K> coder, K key) ASerializableMatcher
that matches anyKV
with the specified key.The key of type
K
will be serialized using the providedCoder
. It is explicitly not required or expected to be serializable via Java serialization. -
kvWithKey
public static <K,V> SerializableMatcher<KV<? extends K,? extends V>> kvWithKey(SerializableMatcher<? super K> keyMatcher) ASerializableMatcher
that matches anyKV
with matching key. -
kvWithValue
public static <K,V extends Serializable> SerializableMatcher<KV<? extends K,? extends V>> kvWithValue(V value) ASerializableMatcher
that matches anyKV
with the specified value. -
kvWithValue
public static <K,V> SerializableMatcher<KV<? extends K,? extends V>> kvWithValue(Coder<V> coder, V value) ASerializableMatcher
that matches anyKV
with the specified value.The value of type
V
will be serialized using the providedCoder
. It is explicitly not required or expected to be serializable via Java serialization. -
kvWithValue
public static <K,V> SerializableMatcher<KV<? extends K,? extends V>> kvWithValue(SerializableMatcher<? super V> valueMatcher) ASerializableMatcher
that matches anyKV
with matching value. -
kv
public static <K,V> SerializableMatcher<KV<? extends K,? extends V>> kv(SerializableMatcher<? super K> keyMatcher, SerializableMatcher<? super V> valueMatcher) ASerializableMatcher
that matches anyKV
with matching key and value. -
lessThan
ASerializableMatcher
with identical criteria toMatchers.lessThan(Comparable)
. -
lessThan
ASerializableMatcher
with identical criteria toMatchers.lessThan(Comparable)
.The target value of type
T
will be serialized using the providedCoder
. It is explicitly not required or expected to be serializable via Java serialization. -
lessThanOrEqualTo
public static <T extends Comparable<T> & Serializable> SerializableMatcher<T> lessThanOrEqualTo(T target) ASerializableMatcher
with identical criteria toMatchers.lessThanOrEqualTo(Comparable)
. -
lessThanOrEqualTo
public static <T extends Comparable<T>> SerializableMatcher<T> lessThanOrEqualTo(Coder<T> coder, T target) ASerializableMatcher
with identical criteria toMatchers.lessThanOrEqualTo(Comparable)
.The target value of type
T
will be serialized using the providedCoder
. It is explicitly not required or expected to be serializable via Java serialization. -
not
ASerializableMatcher
with identical criteria toMatchers.not(org.hamcrest.Matcher<T>)
. -
nullValue
ASerializableMatcher
with identical criteria toMatchers.nullValue()
. -
startsWith
ASerializableMatcher
with identical criteria toMatchers.startsWith(java.lang.String)
. -
fromSupplier
public static <T> SerializableMatcher<T> fromSupplier(org.apache.beam.sdk.util.SerializableSupplier<Matcher<T>> supplier) Constructs aSerializableMatcher
from a non-serializableMatcher
via indirection throughSerializableSupplier
.To wrap a
Matcher
which is not serializable, provide aSerializableSupplier
with aSupplier.get()
method that returns a fresh instance of theMatcher
desired. The resultingSerializableMatcher
will behave according to theMatcher
returned byget()
when it is invoked during matching (which may occur on another machine).return fromSupplier(new SerializableSupplier<Matcher<T>>() { * @Override public Matcher<T> get() { return new MyMatcherForT(); } });
-