Remove various unnecesary qualifiers

This commit is contained in:
Trustin Lee 2012-11-10 07:02:56 +09:00
parent 44159abefa
commit bc7eb20c6e
93 changed files with 114 additions and 188 deletions

View File

@ -55,7 +55,6 @@ public class Bootstrap implements ExternalResourceReleasable {
* I/O operation is requested.
*/
protected Bootstrap() {
super();
}
/**

View File

@ -113,7 +113,6 @@ public class ClientBootstrap extends Bootstrap {
* operation is requested.
*/
public ClientBootstrap() {
super();
}
/**

View File

@ -122,7 +122,6 @@ public class ConnectionlessBootstrap extends Bootstrap {
* operation is requested.
*/
public ConnectionlessBootstrap() {
super();
}
/**

View File

@ -165,7 +165,6 @@ public class ServerBootstrap extends Bootstrap {
* operation is requested.
*/
public ServerBootstrap() {
super();
}
/**

View File

@ -717,11 +717,11 @@ public class CompositeChannelBuffer extends AbstractChannelBuffer {
// New readerIndex and writerIndex will become 0 and
// (previous writerIndex - previous readerIndex) respectively.
final int localReaderIndex = this.readerIndex();
final int localReaderIndex = readerIndex();
if (localReaderIndex == 0) {
return;
}
int localWriterIndex = this.writerIndex();
int localWriterIndex = writerIndex();
final int bytesToMove = capacity() - localReaderIndex;
List<ChannelBuffer> list = decompose(localReaderIndex, bytesToMove);
@ -744,14 +744,14 @@ public class CompositeChannelBuffer extends AbstractChannelBuffer {
int localMarkedReaderIndex = localReaderIndex;
try {
resetReaderIndex();
localMarkedReaderIndex = this.readerIndex();
localMarkedReaderIndex = readerIndex();
} catch (IndexOutOfBoundsException e) {
// ignore
}
int localMarkedWriterIndex = localWriterIndex;
try {
resetWriterIndex();
localMarkedWriterIndex = this.writerIndex();
localMarkedWriterIndex = writerIndex();
} catch (IndexOutOfBoundsException e) {
// ignore
}

View File

@ -99,7 +99,7 @@ public class DirectChannelBufferFactory extends AbstractChannelBufferFactory {
"preallocatedBufCapacity must be greater than 0: " + preallocatedBufferCapacity);
}
this.preallocatedBufCapacity = preallocatedBufferCapacity;
preallocatedBufCapacity = preallocatedBufferCapacity;
}
public ChannelBuffer getBuffer(ByteOrder order, int capacity) {

View File

@ -53,7 +53,6 @@ public class HeapChannelBufferFactory extends AbstractChannelBufferFactory {
* {@link ByteOrder#BIG_ENDIAN}.
*/
public HeapChannelBufferFactory() {
super();
}
/**

View File

@ -146,7 +146,7 @@ public abstract class AbstractChannel implements Channel {
*/
@Override
public final int hashCode() {
return this.id;
return id;
}
/**

View File

@ -26,7 +26,6 @@ public abstract class AbstractChannelSink implements ChannelSink {
* Creates a new instance.
*/
protected AbstractChannelSink() {
super();
}
/**

View File

@ -28,7 +28,6 @@ public class ChannelException extends RuntimeException {
* Creates a new exception.
*/
public ChannelException() {
super();
}
/**

View File

@ -15,6 +15,9 @@
*/
package org.jboss.netty.channel;
import org.jboss.netty.bootstrap.Bootstrap;
import org.jboss.netty.channel.group.ChannelGroup;
import java.lang.annotation.Documented;
import java.lang.annotation.ElementType;
import java.lang.annotation.Inherited;
@ -22,9 +25,6 @@ import java.lang.annotation.Retention;
import java.lang.annotation.RetentionPolicy;
import java.lang.annotation.Target;
import org.jboss.netty.bootstrap.Bootstrap;
import org.jboss.netty.channel.group.ChannelGroup;
/**
* Handles or intercepts a {@link ChannelEvent}, and sends a
* {@link ChannelEvent} to the next handler in a {@link ChannelPipeline}.
@ -224,7 +224,7 @@ public interface ChannelHandler {
@Documented
@Target(ElementType.TYPE)
@Retention(RetentionPolicy.RUNTIME)
public @interface Sharable {
@interface Sharable {
// no value
}
}

View File

@ -30,7 +30,6 @@ public class ChannelHandlerLifeCycleException extends RuntimeException {
* Creates a new exception.
*/
public ChannelHandlerLifeCycleException() {
super();
}
/**

View File

@ -30,7 +30,6 @@ public class ChannelPipelineException extends ChannelException {
* Creates a new instance.
*/
public ChannelPipelineException() {
super();
}
/**

View File

@ -230,7 +230,7 @@ public class DefaultChannelFuture implements ChannelFuture {
checkDeadLock();
waiters++;
try {
this.wait();
wait();
} finally {
waiters--;
}
@ -255,7 +255,7 @@ public class DefaultChannelFuture implements ChannelFuture {
checkDeadLock();
waiters++;
try {
this.wait();
wait();
} catch (InterruptedException e) {
interrupted = true;
} finally {
@ -309,7 +309,7 @@ public class DefaultChannelFuture implements ChannelFuture {
try {
for (;;) {
try {
this.wait(waitTime / 1000000, (int) (waitTime % 1000000));
wait(waitTime / 1000000, (int) (waitTime % 1000000));
} catch (InterruptedException e) {
if (interruptable) {
throw e;

View File

@ -790,7 +790,6 @@ public class DefaultChannelPipeline implements ChannelPipeline {
private static final class DiscardingChannelSink implements ChannelSink {
DiscardingChannelSink() {
super();
}
public void eventSunk(ChannelPipeline pipeline, ChannelEvent e) {

View File

@ -207,7 +207,7 @@ public class DefaultChannelGroupFuture implements ChannelGroupFuture {
checkDeadLock();
waiters++;
try {
this.wait();
wait();
} finally {
waiters--;
}
@ -232,7 +232,7 @@ public class DefaultChannelGroupFuture implements ChannelGroupFuture {
checkDeadLock();
waiters++;
try {
this.wait();
wait();
} catch (InterruptedException e) {
interrupted = true;
} finally {
@ -286,7 +286,7 @@ public class DefaultChannelGroupFuture implements ChannelGroupFuture {
try {
for (;;) {
try {
this.wait(waitTime / 1000000, (int) (waitTime % 1000000));
wait(waitTime / 1000000, (int) (waitTime % 1000000));
} catch (InterruptedException e) {
if (interruptable) {
throw e;

View File

@ -15,7 +15,15 @@
*/
package org.jboss.netty.channel.socket.nio;
import static org.jboss.netty.channel.Channels.*;
import org.jboss.netty.buffer.ChannelBuffer;
import org.jboss.netty.channel.AbstractChannel;
import org.jboss.netty.channel.Channel;
import org.jboss.netty.channel.ChannelFactory;
import org.jboss.netty.channel.ChannelPipeline;
import org.jboss.netty.channel.ChannelSink;
import org.jboss.netty.channel.MessageEvent;
import org.jboss.netty.channel.socket.nio.SocketSendBufferPool.SendBuffer;
import org.jboss.netty.util.internal.ThreadLocalBoolean;
import java.net.InetSocketAddress;
import java.nio.channels.SelectableChannel;
@ -27,15 +35,7 @@ import java.util.concurrent.ConcurrentLinkedQueue;
import java.util.concurrent.atomic.AtomicBoolean;
import java.util.concurrent.atomic.AtomicInteger;
import org.jboss.netty.buffer.ChannelBuffer;
import org.jboss.netty.channel.AbstractChannel;
import org.jboss.netty.channel.Channel;
import org.jboss.netty.channel.ChannelFactory;
import org.jboss.netty.channel.ChannelPipeline;
import org.jboss.netty.channel.ChannelSink;
import org.jboss.netty.channel.MessageEvent;
import org.jboss.netty.channel.socket.nio.SocketSendBufferPool.SendBuffer;
import org.jboss.netty.util.internal.ThreadLocalBoolean;
import static org.jboss.netty.channel.Channels.*;
abstract class AbstractNioChannel<C extends SelectableChannel & WritableByteChannel> extends AbstractChannel {
@ -103,7 +103,7 @@ abstract class AbstractNioChannel<C extends SelectableChannel & WritableByteChan
ChannelSink sink, AbstractNioWorker worker, C ch) {
super(id, parent, factory, pipeline, sink);
this.worker = worker;
this.channel = ch;
channel = ch;
}
protected AbstractNioChannel(
@ -111,7 +111,7 @@ abstract class AbstractNioChannel<C extends SelectableChannel & WritableByteChan
ChannelPipeline pipeline, ChannelSink sink, AbstractNioWorker worker, C ch) {
super(parent, factory, pipeline, sink);
this.worker = worker;
this.channel = ch;
channel = ch;
}
/**
@ -164,7 +164,7 @@ abstract class AbstractNioChannel<C extends SelectableChannel & WritableByteChan
}
void setRawInterestOpsNow(int interestOps) {
super.setInterestOpsNow(interestOps);
setInterestOpsNow(interestOps);
}
@ -214,7 +214,7 @@ abstract class AbstractNioChannel<C extends SelectableChannel & WritableByteChan
private final Queue<MessageEvent> queue;
public WriteRequestQueue() {
this.queue = new ConcurrentLinkedQueue<MessageEvent>();
queue = new ConcurrentLinkedQueue<MessageEvent>();
}
public MessageEvent remove() {

View File

@ -26,7 +26,6 @@ public class PrematureChannelClosureException extends Exception {
private static final long serialVersionUID = 233460005724966593L;
public PrematureChannelClosureException() {
super();
}
public PrematureChannelClosureException(String msg) {

View File

@ -199,7 +199,7 @@ public enum Base64Dialect {
final byte[] decodabet;
final boolean breakLinesByDefault;
private Base64Dialect(byte[] alphabet, byte[] decodabet, boolean breakLinesByDefault) {
Base64Dialect(byte[] alphabet, byte[] decodabet, boolean breakLinesByDefault) {
this.alphabet = alphabet;
this.decodabet = decodabet;
this.breakLinesByDefault = breakLinesByDefault;

View File

@ -29,7 +29,6 @@ public class CompressionException extends RuntimeException {
* Creates a new instance.
*/
public CompressionException() {
super();
}
/**

View File

@ -54,6 +54,5 @@ final class ZlibUtil {
}
private ZlibUtil() {
super();
}
}

View File

@ -183,7 +183,6 @@ abstract class AbstractCodecEmbedder<E> implements CodecEmbedder<E> {
private final class EmbeddedChannelSink implements ChannelSink, ChannelUpstreamHandler {
EmbeddedChannelSink() {
super();
}
public void handleUpstream(ChannelHandlerContext ctx, ChannelEvent e) {
@ -229,7 +228,6 @@ abstract class AbstractCodecEmbedder<E> implements CodecEmbedder<E> {
private static final class EmbeddedChannelPipeline extends DefaultChannelPipeline {
EmbeddedChannelPipeline() {
super();
}
@Override

View File

@ -28,7 +28,6 @@ public class CodecEmbedderException extends RuntimeException {
* Creates a new instance.
*/
public CodecEmbedderException() {
super();
}
/**

View File

@ -68,6 +68,6 @@ public class DecoderEmbedder<E> extends AbstractCodecEmbedder<E> {
public boolean offer(Object input) {
fireMessageReceived(getChannel(), input);
return !super.isEmpty();
return !isEmpty();
}
}

View File

@ -26,7 +26,6 @@ final class EmbeddedChannelFactory implements ChannelFactory {
static final ChannelFactory INSTANCE = new EmbeddedChannelFactory();
private EmbeddedChannelFactory() {
super();
}
public Channel newChannel(ChannelPipeline pipeline) {

View File

@ -29,7 +29,6 @@ public class CorruptedFrameException extends Exception {
* Creates a new instance.
*/
public CorruptedFrameException() {
super();
}
/**

View File

@ -29,7 +29,6 @@ public class TooLongFrameException extends Exception {
* Creates a new instance.
*/
public TooLongFrameException() {
super();
}
/**

View File

@ -47,7 +47,6 @@ public class CookieDecoder {
* Creates a new decoder.
*/
public CookieDecoder() {
super();
}
/**
@ -55,7 +54,6 @@ public class CookieDecoder {
*/
@Deprecated
public CookieDecoder(@SuppressWarnings("unused") boolean lenient) {
super();
}
/**

View File

@ -199,7 +199,7 @@ public class HttpChunkAggregator extends SimpleChannelUpstreamHandler implements
}
protected void appendToCumulation(ChannelBuffer input) {
ChannelBuffer cumulation = this.currentMessage.getContent();
ChannelBuffer cumulation = currentMessage.getContent();
if (cumulation instanceof CompositeChannelBuffer) {
// Make sure the resulting cumulation buffer has no more than the configured components.
CompositeChannelBuffer composite = (CompositeChannelBuffer) cumulation;

View File

@ -100,7 +100,6 @@ public class HttpClientCodec implements ChannelUpstreamHandler,
private final class Encoder extends HttpRequestEncoder {
Encoder() {
super();
}
@Override

View File

@ -130,6 +130,5 @@ final class HttpCodecUtil {
}
private HttpCodecUtil() {
super();
}
}

View File

@ -53,7 +53,6 @@ public abstract class HttpContentDecoder extends SimpleChannelUpstreamHandler
* Creates a new instance.
*/
protected HttpContentDecoder() {
super();
}
@Override

View File

@ -59,7 +59,6 @@ public abstract class HttpContentEncoder extends SimpleChannelHandler
* Creates a new instance.
*/
protected HttpContentEncoder() {
super();
}
@Override

View File

@ -334,7 +334,6 @@ public class HttpHeaders {
public static final String WWW_AUTHENTICATE = "WWW-Authenticate";
private Names() {
super();
}
}
@ -473,7 +472,6 @@ public class HttpHeaders {
public static final String WEBSOCKET = "WebSocket";
private Values() {
super();
}
}

View File

@ -114,7 +114,7 @@ public abstract class HttpMessageDecoder extends ReplayingDecoder<HttpMessageDec
* <em>Internal use only</em>.
* @apiviz.exclude
*/
protected static enum State {
protected enum State {
SKIP_CONTROL_CHARS,
READ_INITIAL,
READ_HEADER,

View File

@ -56,7 +56,6 @@ public abstract class HttpMessageEncoder extends OneToOneEncoder {
* Creates a new instance.
*/
protected HttpMessageEncoder() {
super();
}
@Override

View File

@ -60,7 +60,6 @@ public class HttpRequestDecoder extends HttpMessageDecoder {
* {@code maxChunkSize (8192)}.
*/
public HttpRequestDecoder() {
super();
}
/**

View File

@ -89,7 +89,6 @@ public class HttpResponseDecoder extends HttpMessageDecoder {
* {@code maxChunkSize (8192)}.
*/
public HttpResponseDecoder() {
super();
}
/**

View File

@ -52,7 +52,6 @@ public abstract class OneToOneDecoder implements ChannelUpstreamHandler {
* Creates a new instance with the current system character set.
*/
protected OneToOneDecoder() {
super();
}
public void handleUpstream(

View File

@ -46,7 +46,6 @@ import org.jboss.netty.handler.codec.frame.Delimiters;
public abstract class OneToOneEncoder implements ChannelDownstreamHandler {
protected OneToOneEncoder() {
super();
}
public void handleDownstream(

View File

@ -310,7 +310,7 @@ public abstract class ReplayingDecoder<T extends Enum<T>>
protected ReplayingDecoder(T initialState, boolean unfold) {
super(unfold);
this.state = initialState;
state = initialState;
}
@Override

View File

@ -31,7 +31,6 @@ public class UnreplayableOperationException extends
* Creates a new instance.
*/
public UnreplayableOperationException() {
super();
}
/**

View File

@ -207,7 +207,6 @@ public final class RtspHeaders {
public static final String WWW_AUTHENTICATE = HttpHeaders.Names.WWW_AUTHENTICATE;
private Names() {
super();
}
}
@ -385,11 +384,9 @@ public final class RtspHeaders {
public static final String URL = "url";
protected Values() {
super();
}
}
private RtspHeaders() {
super();
}
}

View File

@ -36,7 +36,6 @@ public abstract class RtspMessageEncoder extends HttpMessageEncoder {
* Creates a new instance.
*/
protected RtspMessageEncoder() {
super();
}
@Override

View File

@ -136,6 +136,5 @@ public final class RtspMethods {
}
private RtspMethods() {
super();
}
}

View File

@ -56,7 +56,6 @@ public class RtspRequestDecoder extends RtspMessageDecoder {
* {@code maxContentLength (8192)}.
*/
public RtspRequestDecoder() {
super();
}
/**

View File

@ -57,7 +57,6 @@ public class RtspResponseDecoder extends RtspMessageDecoder {
* {@code maxContentLength (8192)}.
*/
public RtspResponseDecoder() {
super();
}
/**

View File

@ -290,6 +290,5 @@ public final class RtspResponseStatuses {
}
private RtspResponseStatuses() {
super();
}
}

View File

@ -48,6 +48,5 @@ public final class RtspVersions {
}
private RtspVersions() {
super();
}
}

View File

@ -33,7 +33,6 @@ public class DefaultSpdyHeadersFrame extends DefaultSpdyHeaderBlock
* @param streamId the Stream-ID of this frame
*/
public DefaultSpdyHeadersFrame(int streamId) {
super();
setStreamId(streamId);
}

View File

@ -52,7 +52,7 @@ public class SpdyFrameDecoder extends FrameDecoder {
private int numHeaders;
private ChannelBuffer decompressed;
private static enum State {
private enum State {
READ_COMMON_HEADER,
READ_CONTROL_FRAME,
READ_SETTINGS_FRAME,

View File

@ -63,7 +63,6 @@ public class SpdyHeaders {
public static final String VERSION = ":version";
private HttpNames() {
super();
}
}
@ -94,7 +93,6 @@ public class SpdyHeaders {
public static final String VERSION = "version";
private Spdy2HttpNames() {
super();
}
}

View File

@ -68,7 +68,6 @@ public class SpdyHttpDecoder extends OneToOneDecoder {
* a {@link TooLongFrameException} will be raised.
*/
public SpdyHttpDecoder(int version, int maxContentLength) {
super();
if (version < SPDY_MIN_VERSION || version > SPDY_MAX_VERSION) {
throw new IllegalArgumentException(
"unsupported version: " + version);

View File

@ -52,7 +52,6 @@ public final class SpdyHttpHeaders {
public static final String SCHEME = "X-SPDY-Scheme";
private Names() {
super();
}
}

View File

@ -36,7 +36,7 @@ import org.jboss.netty.handler.ssl.SslHandler;
*/
public abstract class SpdyOrHttpChooser implements ChannelUpstreamHandler {
public static enum SelectedProtocol {
public enum SelectedProtocol {
SpdyVersion2,
SpdyVersion3,
HttpVersion1_1,

View File

@ -28,7 +28,6 @@ public class SpdyProtocolException extends Exception {
* Creates a new instance.
*/
public SpdyProtocolException() {
super();
}
/**

View File

@ -256,7 +256,6 @@ final class SpdySession {
private final class PriorityComparator implements Comparator<Integer> {
PriorityComparator() {
super();
}
public int compare(Integer id1, Integer id2) {

View File

@ -87,7 +87,6 @@ public class SpdySessionHandler extends SimpleChannelUpstreamHandler
* handle the client endpoint of the connection.
*/
public SpdySessionHandler(int version, boolean server) {
super();
if (version < SPDY_MIN_VERSION || version > SPDY_MAX_VERSION) {
throw new IllegalArgumentException(
"unsupported version: " + version);

View File

@ -78,10 +78,10 @@ public class IpFilterRuleList extends ArrayList<IpFilterRule> {
boolean allow = rule.startsWith("+");
if (rule.charAt(1) == 'n' || rule.charAt(1) == 'i') {
this.add(new PatternRule(allow, rule.substring(1)));
add(new PatternRule(allow, rule.substring(1)));
} else if (rule.charAt(1) == 'c') {
try {
this.add(new IpSubnetFilterRule(allow, rule.substring(3)));
add(new IpSubnetFilterRule(allow, rule.substring(3)));
} catch (UnknownHostException e) {
if (logger.isErrorEnabled()) {
logger.error("error parsing ip filter " + rule, e);

View File

@ -15,12 +15,12 @@
*/
package org.jboss.netty.handler.ipfilter;
import java.net.InetAddress;
import java.net.UnknownHostException;
import org.jboss.netty.logging.InternalLogger;
import org.jboss.netty.logging.InternalLoggerFactory;
import java.net.InetAddress;
import java.net.UnknownHostException;
/**
* This class allows to check if an IP V4 or V6 Address is contained in a subnet.<BR>
* <p/>
@ -101,7 +101,7 @@ public class IpSubnet implements IpSet, Comparable<IpSubnet> {
*/
public boolean contains(String ipAddr) throws UnknownHostException {
InetAddress inetAddress1 = InetAddress.getByName(ipAddr);
return this.contains(inetAddress1);
return contains(inetAddress1);
}
/**

View File

@ -133,7 +133,7 @@ public class IpV4Subnet implements IpSet, Comparable<IpV4Subnet> {
*/
private void setNetId(String netId) throws UnknownHostException {
InetAddress inetAddress1 = InetAddress.getByName(netId);
this.setNetId(inetAddress1);
setNetId(inetAddress1);
}
/**
@ -199,7 +199,7 @@ public class IpV4Subnet implements IpSet, Comparable<IpV4Subnet> {
*/
public boolean contains(String ipAddr) throws UnknownHostException {
InetAddress inetAddress1 = InetAddress.getByName(ipAddr);
return this.contains(inetAddress1);
return contains(inetAddress1);
}
/**

View File

@ -30,7 +30,6 @@ public class BlockingReadTimeoutException extends InterruptedIOException {
* Creates a new instance.
*/
public BlockingReadTimeoutException() {
super();
}
/**

View File

@ -481,7 +481,7 @@ public class SslHandler extends FrameDecoder
if (ctx != null) {
throw new IllegalStateException("Can only get changed before attached to ChannelPipeline");
}
this.closeOnSSLException = closeOnSslException;
closeOnSSLException = closeOnSslException;
}
public boolean getCloseOnSSLException() {

View File

@ -498,7 +498,6 @@ public class IdleStateHandler extends SimpleChannelUpstreamHandler
volatile Timeout allIdleTimeout;
State() {
super();
}
}
}

View File

@ -27,7 +27,6 @@ public class ReadTimeoutException extends TimeoutException {
* Creates a new instance.
*/
public ReadTimeoutException() {
super();
}
/**

View File

@ -289,7 +289,6 @@ public class ReadTimeoutHandler extends SimpleChannelUpstreamHandler
volatile long lastReadTime = System.currentTimeMillis();
State() {
super();
}
}
}

View File

@ -29,7 +29,6 @@ public class TimeoutException extends ChannelException {
* Creates a new instance.
*/
public TimeoutException() {
super();
}
/**

View File

@ -28,7 +28,6 @@ public class WriteTimeoutException extends TimeoutException {
* Creates a new instance.
*/
public WriteTimeoutException() {
super();
}
/**

View File

@ -273,8 +273,8 @@ public abstract class AbstractTrafficShapingHandler extends
*/
public void configure(long newWriteLimit, long newReadLimit,
long newCheckInterval) {
this.configure(newWriteLimit, newReadLimit);
this.configure(newCheckInterval);
configure(newWriteLimit, newReadLimit);
configure(newCheckInterval);
}
/**

View File

@ -26,7 +26,6 @@ public abstract class AbstractInternalLogger implements InternalLogger {
* Creates a new instance.
*/
protected AbstractInternalLogger() {
super();
}
public boolean isEnabled(InternalLogLevel level) {

View File

@ -41,6 +41,5 @@ public final class ExternalResourceUtil {
}
private ExternalResourceUtil() {
super();
}
}

View File

@ -363,7 +363,6 @@ public class HashedWheelTimer implements Timer {
private long tick;
Worker() {
super();
}
public void run() {

View File

@ -25,7 +25,6 @@ public final class CaseIgnoringComparator implements Comparator<String>, Seriali
public static final CaseIgnoringComparator INSTANCE = new CaseIgnoringComparator();
private CaseIgnoringComparator() {
super();
}
public int compare(String o1, String o2) {

View File

@ -611,7 +611,7 @@ public final class ConcurrentHashMap<K, V> extends AbstractMap<K, V>
}
segmentShift = 32 - sshift;
segmentMask = ssize - 1;
this.segments = Segment.newArray(ssize);
segments = Segment.newArray(ssize);
if (initialCapacity > MAXIMUM_CAPACITY) {
initialCapacity = MAXIMUM_CAPACITY;
@ -625,8 +625,8 @@ public final class ConcurrentHashMap<K, V> extends AbstractMap<K, V>
cap <<= 1;
}
for (int i = 0; i < this.segments.length; ++ i) {
this.segments[i] = new Segment<K, V>(cap, loadFactor);
for (int i = 0; i < segments.length; ++ i) {
segments[i] = new Segment<K, V>(cap, loadFactor);
}
}
@ -1178,11 +1178,11 @@ public final class ConcurrentHashMap<K, V> extends AbstractMap<K, V>
extends HashIterator implements ReusableIterator<K>, Enumeration<K> {
public K next() {
return super.nextEntry().key();
return nextEntry().key();
}
public K nextElement() {
return super.nextEntry().key();
return nextEntry().key();
}
}
@ -1190,11 +1190,11 @@ public final class ConcurrentHashMap<K, V> extends AbstractMap<K, V>
extends HashIterator implements ReusableIterator<V>, Enumeration<V> {
public V next() {
return super.nextEntry().value();
return nextEntry().value();
}
public V nextElement() {
return super.nextEntry().value();
return nextEntry().value();
}
}
@ -1214,8 +1214,8 @@ public final class ConcurrentHashMap<K, V> extends AbstractMap<K, V>
}
public SimpleEntry(Entry<? extends K, ? extends V> entry) {
this.key = entry.getKey();
this.value = entry.getValue();
key = entry.getKey();
value = entry.getValue();
}
@ -1283,7 +1283,7 @@ public final class ConcurrentHashMap<K, V> extends AbstractMap<K, V>
throw new NullPointerException();
}
V v = super.setValue(value);
ConcurrentHashMap.this.put(getKey(), value);
put(getKey(), value);
return v;
}
@ -1292,7 +1292,7 @@ public final class ConcurrentHashMap<K, V> extends AbstractMap<K, V>
final class EntryIterator extends HashIterator implements
ReusableIterator<Entry<K, V>> {
public Map.Entry<K, V> next() {
HashEntry<K, V> e = super.nextEntry();
HashEntry<K, V> e = nextEntry();
return new WriteThroughEntry(e.key(), e.value());
}
}
@ -1316,7 +1316,7 @@ public final class ConcurrentHashMap<K, V> extends AbstractMap<K, V>
@Override
public boolean contains(Object o) {
return ConcurrentHashMap.this.containsKey(o);
return containsKey(o);
}
@Override
@ -1349,7 +1349,7 @@ public final class ConcurrentHashMap<K, V> extends AbstractMap<K, V>
@Override
public boolean contains(Object o) {
return ConcurrentHashMap.this.containsValue(o);
return containsValue(o);
}
@Override
@ -1370,7 +1370,7 @@ public final class ConcurrentHashMap<K, V> extends AbstractMap<K, V>
return false;
}
Map.Entry<?, ?> e = (Map.Entry<?, ?>) o;
V v = ConcurrentHashMap.this.get(e.getKey());
V v = get(e.getKey());
return v != null && v.equals(e.getValue());
}

View File

@ -611,7 +611,7 @@ public final class ConcurrentIdentityHashMap<K, V> extends AbstractMap<K, V>
}
segmentShift = 32 - sshift;
segmentMask = ssize - 1;
this.segments = Segment.newArray(ssize);
segments = Segment.newArray(ssize);
if (initialCapacity > MAXIMUM_CAPACITY) {
initialCapacity = MAXIMUM_CAPACITY;
@ -625,8 +625,8 @@ public final class ConcurrentIdentityHashMap<K, V> extends AbstractMap<K, V>
cap <<= 1;
}
for (int i = 0; i < this.segments.length; ++ i) {
this.segments[i] = new Segment<K, V>(cap, loadFactor);
for (int i = 0; i < segments.length; ++ i) {
segments[i] = new Segment<K, V>(cap, loadFactor);
}
}
@ -1178,11 +1178,11 @@ public final class ConcurrentIdentityHashMap<K, V> extends AbstractMap<K, V>
extends HashIterator implements ReusableIterator<K>, Enumeration<K> {
public K next() {
return super.nextEntry().key();
return nextEntry().key();
}
public K nextElement() {
return super.nextEntry().key();
return nextEntry().key();
}
}
@ -1190,11 +1190,11 @@ public final class ConcurrentIdentityHashMap<K, V> extends AbstractMap<K, V>
extends HashIterator implements ReusableIterator<V>, Enumeration<V> {
public V next() {
return super.nextEntry().value();
return nextEntry().value();
}
public V nextElement() {
return super.nextEntry().value();
return nextEntry().value();
}
}
@ -1214,8 +1214,8 @@ public final class ConcurrentIdentityHashMap<K, V> extends AbstractMap<K, V>
}
public SimpleEntry(Entry<? extends K, ? extends V> entry) {
this.key = entry.getKey();
this.value = entry.getValue();
key = entry.getKey();
value = entry.getValue();
}
@ -1283,7 +1283,7 @@ public final class ConcurrentIdentityHashMap<K, V> extends AbstractMap<K, V>
throw new NullPointerException();
}
V v = super.setValue(value);
ConcurrentIdentityHashMap.this.put(getKey(), value);
put(getKey(), value);
return v;
}
@ -1292,7 +1292,7 @@ public final class ConcurrentIdentityHashMap<K, V> extends AbstractMap<K, V>
final class EntryIterator extends HashIterator implements
ReusableIterator<Entry<K, V>> {
public Map.Entry<K, V> next() {
HashEntry<K, V> e = super.nextEntry();
HashEntry<K, V> e = nextEntry();
return new WriteThroughEntry(e.key(), e.value());
}
}
@ -1316,7 +1316,7 @@ public final class ConcurrentIdentityHashMap<K, V> extends AbstractMap<K, V>
@Override
public boolean contains(Object o) {
return ConcurrentIdentityHashMap.this.containsKey(o);
return containsKey(o);
}
@Override
@ -1349,7 +1349,7 @@ public final class ConcurrentIdentityHashMap<K, V> extends AbstractMap<K, V>
@Override
public boolean contains(Object o) {
return ConcurrentIdentityHashMap.this.containsValue(o);
return containsValue(o);
}
@Override
@ -1370,7 +1370,7 @@ public final class ConcurrentIdentityHashMap<K, V> extends AbstractMap<K, V>
return false;
}
Map.Entry<?, ?> e = (Map.Entry<?, ?>) o;
V v = ConcurrentIdentityHashMap.this.get(e.getKey());
V v = get(e.getKey());
return v != null && v.equals(e.getValue());
}

View File

@ -192,8 +192,8 @@ public final class ConcurrentIdentityWeakKeyHashMap<K, V> extends AbstractMap<K,
ReferenceQueue<Object> refQueue) {
this.hash = hash;
this.next = next;
this.keyRef = new WeakKeyReference<K>(key, hash, refQueue);
this.valueRef = value;
keyRef = new WeakKeyReference<K>(key, hash, refQueue);
valueRef = value;
}
@SuppressWarnings("unchecked")
@ -215,7 +215,7 @@ public final class ConcurrentIdentityWeakKeyHashMap<K, V> extends AbstractMap<K,
}
void setValue(V value) {
this.valueRef = value;
valueRef = value;
}
@SuppressWarnings("unchecked")
@ -675,7 +675,7 @@ public final class ConcurrentIdentityWeakKeyHashMap<K, V> extends AbstractMap<K,
}
segmentShift = 32 - sshift;
segmentMask = ssize - 1;
this.segments = Segment.newArray(ssize);
segments = Segment.newArray(ssize);
if (initialCapacity > MAXIMUM_CAPACITY) {
initialCapacity = MAXIMUM_CAPACITY;
@ -689,8 +689,8 @@ public final class ConcurrentIdentityWeakKeyHashMap<K, V> extends AbstractMap<K,
cap <<= 1;
}
for (int i = 0; i < this.segments.length; ++ i) {
this.segments[i] = new Segment<K, V>(cap, loadFactor);
for (int i = 0; i < segments.length; ++ i) {
segments[i] = new Segment<K, V>(cap, loadFactor);
}
}
@ -1258,11 +1258,11 @@ public final class ConcurrentIdentityWeakKeyHashMap<K, V> extends AbstractMap<K,
extends HashIterator implements ReusableIterator<K>, Enumeration<K> {
public K next() {
return super.nextEntry().key();
return nextEntry().key();
}
public K nextElement() {
return super.nextEntry().key();
return nextEntry().key();
}
}
@ -1270,11 +1270,11 @@ public final class ConcurrentIdentityWeakKeyHashMap<K, V> extends AbstractMap<K,
extends HashIterator implements ReusableIterator<V>, Enumeration<V> {
public V next() {
return super.nextEntry().value();
return nextEntry().value();
}
public V nextElement() {
return super.nextEntry().value();
return nextEntry().value();
}
}
@ -1294,8 +1294,8 @@ public final class ConcurrentIdentityWeakKeyHashMap<K, V> extends AbstractMap<K,
}
public SimpleEntry(Entry<? extends K, ? extends V> entry) {
this.key = entry.getKey();
this.value = entry.getValue();
key = entry.getKey();
value = entry.getValue();
}
@ -1363,7 +1363,7 @@ public final class ConcurrentIdentityWeakKeyHashMap<K, V> extends AbstractMap<K,
throw new NullPointerException();
}
V v = super.setValue(value);
ConcurrentIdentityWeakKeyHashMap.this.put(getKey(), value);
put(getKey(), value);
return v;
}
@ -1372,7 +1372,7 @@ public final class ConcurrentIdentityWeakKeyHashMap<K, V> extends AbstractMap<K,
final class EntryIterator extends HashIterator implements
ReusableIterator<Entry<K, V>> {
public Map.Entry<K, V> next() {
HashEntry<K, V> e = super.nextEntry();
HashEntry<K, V> e = nextEntry();
return new WriteThroughEntry(e.key(), e.value());
}
}
@ -1396,7 +1396,7 @@ public final class ConcurrentIdentityWeakKeyHashMap<K, V> extends AbstractMap<K,
@Override
public boolean contains(Object o) {
return ConcurrentIdentityWeakKeyHashMap.this.containsKey(o);
return containsKey(o);
}
@Override
@ -1429,7 +1429,7 @@ public final class ConcurrentIdentityWeakKeyHashMap<K, V> extends AbstractMap<K,
@Override
public boolean contains(Object o) {
return ConcurrentIdentityWeakKeyHashMap.this.containsValue(o);
return containsValue(o);
}
@Override
@ -1450,7 +1450,7 @@ public final class ConcurrentIdentityWeakKeyHashMap<K, V> extends AbstractMap<K,
return false;
}
Map.Entry<?, ?> e = (Map.Entry<?, ?>) o;
V v = ConcurrentIdentityWeakKeyHashMap.this.get(e.getKey());
V v = get(e.getKey());
return v != null && v.equals(e.getValue());
}

View File

@ -192,8 +192,8 @@ public final class ConcurrentWeakKeyHashMap<K, V> extends AbstractMap<K, V> impl
ReferenceQueue<Object> refQueue) {
this.hash = hash;
this.next = next;
this.keyRef = new WeakKeyReference<K>(key, hash, refQueue);
this.valueRef = value;
keyRef = new WeakKeyReference<K>(key, hash, refQueue);
valueRef = value;
}
@SuppressWarnings("unchecked")
@ -215,7 +215,7 @@ public final class ConcurrentWeakKeyHashMap<K, V> extends AbstractMap<K, V> impl
}
void setValue(V value) {
this.valueRef = value;
valueRef = value;
}
@SuppressWarnings("unchecked")
@ -675,7 +675,7 @@ public final class ConcurrentWeakKeyHashMap<K, V> extends AbstractMap<K, V> impl
}
segmentShift = 32 - sshift;
segmentMask = ssize - 1;
this.segments = Segment.newArray(ssize);
segments = Segment.newArray(ssize);
if (initialCapacity > MAXIMUM_CAPACITY) {
initialCapacity = MAXIMUM_CAPACITY;
@ -689,8 +689,8 @@ public final class ConcurrentWeakKeyHashMap<K, V> extends AbstractMap<K, V> impl
cap <<= 1;
}
for (int i = 0; i < this.segments.length; ++ i) {
this.segments[i] = new Segment<K, V>(cap, loadFactor);
for (int i = 0; i < segments.length; ++ i) {
segments[i] = new Segment<K, V>(cap, loadFactor);
}
}
@ -1258,11 +1258,11 @@ public final class ConcurrentWeakKeyHashMap<K, V> extends AbstractMap<K, V> impl
extends HashIterator implements ReusableIterator<K>, Enumeration<K> {
public K next() {
return super.nextEntry().key();
return nextEntry().key();
}
public K nextElement() {
return super.nextEntry().key();
return nextEntry().key();
}
}
@ -1270,11 +1270,11 @@ public final class ConcurrentWeakKeyHashMap<K, V> extends AbstractMap<K, V> impl
extends HashIterator implements ReusableIterator<V>, Enumeration<V> {
public V next() {
return super.nextEntry().value();
return nextEntry().value();
}
public V nextElement() {
return super.nextEntry().value();
return nextEntry().value();
}
}
@ -1294,8 +1294,8 @@ public final class ConcurrentWeakKeyHashMap<K, V> extends AbstractMap<K, V> impl
}
public SimpleEntry(Entry<? extends K, ? extends V> entry) {
this.key = entry.getKey();
this.value = entry.getValue();
key = entry.getKey();
value = entry.getValue();
}
@ -1363,7 +1363,7 @@ public final class ConcurrentWeakKeyHashMap<K, V> extends AbstractMap<K, V> impl
throw new NullPointerException();
}
V v = super.setValue(value);
ConcurrentWeakKeyHashMap.this.put(getKey(), value);
put(getKey(), value);
return v;
}
@ -1372,7 +1372,7 @@ public final class ConcurrentWeakKeyHashMap<K, V> extends AbstractMap<K, V> impl
final class EntryIterator extends HashIterator implements
ReusableIterator<Entry<K, V>> {
public Map.Entry<K, V> next() {
HashEntry<K, V> e = super.nextEntry();
HashEntry<K, V> e = nextEntry();
return new WriteThroughEntry(e.key(), e.value());
}
}
@ -1396,7 +1396,7 @@ public final class ConcurrentWeakKeyHashMap<K, V> extends AbstractMap<K, V> impl
@Override
public boolean contains(Object o) {
return ConcurrentWeakKeyHashMap.this.containsKey(o);
return containsKey(o);
}
@Override
@ -1429,7 +1429,7 @@ public final class ConcurrentWeakKeyHashMap<K, V> extends AbstractMap<K, V> impl
@Override
public boolean contains(Object o) {
return ConcurrentWeakKeyHashMap.this.containsValue(o);
return containsValue(o);
}
@Override
@ -1450,7 +1450,7 @@ public final class ConcurrentWeakKeyHashMap<K, V> extends AbstractMap<K, V> impl
return false;
}
Map.Entry<?, ?> e = (Map.Entry<?, ?>) o;
V v = ConcurrentWeakKeyHashMap.this.get(e.getKey());
V v = get(e.getKey());
return v != null && v.equals(e.getValue());
}

View File

@ -48,6 +48,5 @@ public final class DeadLockProofWorker {
}
private DeadLockProofWorker() {
super();
}
}

View File

@ -121,6 +121,5 @@ public final class ExecutorUtil {
}
private ExecutorUtil() {
super();
}
}

View File

@ -102,7 +102,7 @@ public final class JZlib {
// Bit length codes must not exceed MAX_BL_BITS bits
static final int MAX_BL_BITS = 7;
static enum WrapperType {
enum WrapperType {
NONE, ZLIB, GZIP, ZLIB_OR_NONE
}

View File

@ -203,7 +203,6 @@ public abstract class AbstractSocketServerBootstrapTest {
final StringBuffer result = new StringBuffer();
ParentChannelHandler() {
super();
}
@Override

View File

@ -114,7 +114,6 @@ public class CompleteChannelFutureTest {
private static final long serialVersionUID = 7059276744882005047L;
ExpectedError() {
super();
}
}
}

View File

@ -145,7 +145,6 @@ public abstract class AbstractSocketEchoTest {
volatile int counter;
EchoHandler() {
super();
}
@Override

View File

@ -89,7 +89,6 @@ public class NioServerSocketShutdownTimeTest {
volatile boolean closed;
DummyHandler() {
super();
}
@Override

View File

@ -147,7 +147,6 @@ public abstract class AbstractSocketFixedLengthEchoTest {
volatile int counter;
EchoHandler() {
super();
}
@Override

View File

@ -77,17 +77,17 @@ public class WebSocketRequestBuilder {
}
public WebSocketRequestBuilder version13() {
this.version = WebSocketVersion.V13;
version = WebSocketVersion.V13;
return this;
}
public WebSocketRequestBuilder version8() {
this.version = WebSocketVersion.V08;
version = WebSocketVersion.V08;
return this;
}
public WebSocketRequestBuilder version00() {
this.version = null;
version = null;
return this;
}

View File

@ -96,7 +96,6 @@ public class ReplayingDecoderTest {
private static final class LineDecoder extends ReplayingDecoder<VoidEnum> {
LineDecoder() {
super();
}
@Override

View File

@ -155,7 +155,6 @@ public abstract class AbstractSocketCompatibleObjectStreamEchoTest {
volatile int counter;
EchoHandler() {
super();
}
@Override

View File

@ -156,7 +156,6 @@ public abstract class AbstractSocketObjectStreamEchoTest {
volatile int counter;
EchoHandler() {
super();
}
@Override

View File

@ -259,7 +259,6 @@ public abstract class AbstractSocketSpdyEchoTest {
final boolean server;
EchoHandler(ChannelBuffer frames, boolean server) {
super();
this.frames = frames;
this.server = server;
}

View File

@ -273,7 +273,6 @@ public class SpdySessionHandlerTest {
private final boolean server;
EchoHandler(int closeSignal, boolean server) {
super();
this.closeSignal = closeSignal;
this.server = server;
}

View File

@ -160,7 +160,6 @@ public abstract class AbstractSocketStringEchoTest {
volatile int counter;
EchoHandler() {
super();
}
@Override

View File

@ -87,7 +87,6 @@ public class ThreadRenamingRunnableTest {
private static class ImmediateExecutor implements Executor {
ImmediateExecutor() {
super();
}
public void execute(Runnable command) {