Search Java Classes and Packages

Search Java Frameworks and Libraries

255581 classes and counting ...
Search Tips Index Status



#Java.util Classes and Interfaces - 452 results found.
NameDescriptionTypePackageFramework
AbstractCollectionThis class provides a skeletal implementation of the Collection interface, to minimize the effort required to implement this interface.Classjava.utilJava SE
AbstractExecutorServiceProvides default implementations of ExecutorService execution methods.Classjava.util.concurrentJava SE
AbstractListThis class provides a skeletal implementation of the List interface to minimize the effort required to implement this interfaceClassjava.utilJava SE
AbstractMapThis class provides a skeletal implementation of the Map interface, to minimize the effort required to implement this interface.Classjava.utilJava SE
AbstractMap .SimpleEntryAn Entry maintaining a key and a value.Classjava.util.AbstractMapJava SE
AbstractMap .SimpleImmutableEntryAn Entry maintaining an immutable key and value.Classjava.util.AbstractMapJava SE
AbstractOwnableSynchronizerA synchronizer that may be exclusively owned by a thread.Classjava.util.concurrent.locksJava SE
AbstractPreferencesThis class provides a skeletal implementation of the Preferences class, greatly easing the task of implementing it.Classjava.util.prefsJava SE
AbstractQueueThis class provides skeletal implementations of some Queue operations.Classjava.utilJava SE
AbstractQueuedLongSynchronizerA version of AbstractQueuedSynchronizer in which synchronization state is maintained as a long.Classjava.util.concurrent.locksJava SE
AbstractQueuedSynchronizerProvides a framework for implementing blocking locks and related synchronizers (semaphores, events, etc) that rely onClassjava.util.concurrent.locksJava SE
AbstractSequentialListThis class provides a skeletal implementation of the List interface to minimize the effort required to implement this interfaceClassjava.utilJava SE
AbstractSetThis class provides a skeletal implementation of the Set interface to minimize the effort required to implement thisClassjava.utilJava SE
Adler32A class that can be used to compute the Adler-32 checksum of a data stream.Classjava.util.zipJava SE
ArrayBlockingQueueA bounded blocking queue backed by an array.Classjava.util.concurrentJava SE
ArrayDequeResizable-array implementation of the Deque interface.Classjava.utilJava SE
ArrayListResizable-array implementation of the List interface.Classjava.utilJava SE
ArraysThis class contains various methods for manipulating arrays (such as sorting and searching).Classjava.utilJava SE
AtomicBooleanA boolean value that may be updated atomically.Classjava.util.concurrent.atomicJava SE
AtomicIntegerAn int value that may be updated atomically.Classjava.util.concurrent.atomicJava SE
AtomicIntegerArrayAn int array in which elements may be updated atomically.Classjava.util.concurrent.atomicJava SE
AtomicIntegerFieldUpdaterA reflection-based utility that enables atomic updates to designated volatile int fields of designated classes.Classjava.util.concurrent.atomicJava SE
AtomicLongA long value that may be updated atomically.Classjava.util.concurrent.atomicJava SE
AtomicLongArrayA long array in which elements may be updated atomically.Classjava.util.concurrent.atomicJava SE
AtomicLongFieldUpdaterA reflection-based utility that enables atomic updates to designated volatile long fields of designated classes.Classjava.util.concurrent.atomicJava SE
AtomicMarkableReferenceAn AtomicMarkableReference maintains an object reference along with a mark bit, that can be updated atomically.Classjava.util.concurrent.atomicJava SE
AtomicReferenceAn object reference that may be updated atomically.Classjava.util.concurrent.atomicJava SE
AtomicReferenceArrayAn array of object references in which elements may be updated atomically.Classjava.util.concurrent.atomicJava SE
AtomicReferenceFieldUpdaterA reflection-based utility that enables atomic updates to designated volatile reference fields of designatedClassjava.util.concurrent.atomicJava SE
AtomicStampedReferenceAn AtomicStampedReference maintains an object reference along with an integer stamp, that can be updated atomically.Classjava.util.concurrent.atomicJava SE
AttributesThe Attributes class maps Manifest attribute names to associated string values.Classjava.util.jarJava SE
Attributes .NameThe Attributes.Classjava.util.jar.AttributesJava SE
BackingStoreExceptionThrown to indicate that a preferences operation could not complete because of a failure in the backing store, or a failure to contact the backingClassjava.util.prefsJava SE
Base64This class consists exclusively of static methods for obtaining encoders and decoders for the Base64 encoding scheme.Classjava.utilJava SE
Base64 .DecoderThis class implements a decoder for decoding byte data using the Base64 encoding scheme as specified in RFC 4648 and RFC 2045.Classjava.util.Base64Java SE
Base64 .EncoderThis class implements an encoder for encoding byte data using the Base64 encoding scheme as specified in RFC 4648 and RFC 2045.Classjava.util.Base64Java SE
BitSetThis class implements a vector of bits that grows as needed.Classjava.utilJava SE
BrokenBarrierExceptionException thrown when a thread tries to wait upon a barrier that is in a broken state, or which enters the broken state while the threadClassjava.util.concurrentJava SE
BaseStreamBase interface for streams, which are sequences of elements supporting sequential and parallel aggregate operations.Interfacejava.util.streamJava SE
BiConsumerRepresents an operation that accepts two input arguments and returns no result.Interfacejava.util.functionJava SE
BiFunctionRepresents a function that accepts two arguments and produces a result.Interfacejava.util.functionJava SE
BinaryOperatorRepresents an operation upon two operands of the same type, producing a result of the same type as the operands.Interfacejava.util.functionJava SE
BiPredicateRepresents a predicate (boolean-valued function) of two arguments.Interfacejava.util.functionJava SE
BlockingDequeA Deque that additionally supports blocking operations that wait for the deque to become non-empty when retrieving an element, and wait forInterfacejava.util.concurrentJava SE
BlockingQueueA Queue that additionally supports operations that wait for the queue to become non-empty when retrieving anInterfacejava.util.concurrentJava SE
BooleanSupplierRepresents a supplier of boolean-valued results.Interfacejava.util.functionJava SE
CalendarThe Calendar class is an abstract class that provides methods for converting between a specific instant in time and a set of calendar fields such as YEAR, MONTH,Classjava.utilJava SE
Calendar .BuilderCalendar.Classjava.util.CalendarJava SE
CalendarDataProviderAn abstract class for service providers that provide locale-dependent Calendar parameters.Classjava.util.spiJava SE
CalendarNameProviderAn abstract class for service providers that provide localized string representations (display names) of Calendar field values.Classjava.util.spiJava SE
CancellationExceptionException indicating that the result of a value-producing task, such as a FutureTask, cannot be retrieved because the taskClassjava.util.concurrentJava SE
CheckedInputStreamAn input stream that also maintains a checksum of the data being read.Classjava.util.zipJava SE
CheckedOutputStreamAn output stream that also maintains a checksum of the data being written.Classjava.util.zipJava SE
CollectionsThis class consists exclusively of static methods that operate on or return collections.Classjava.utilJava SE
Collectors operations, such as accumulating elements into collections, summarizing elements according to various criteria, etc.Classjava.util.streamJava SE
CompletableFutureA Future that may be explicitly completed (setting its value and status), and may be used as a CompletionStage,Classjava.util.concurrentJava SE
CompletionExceptionException thrown when an error or other exception is encountered in the course of completing a result or task.Classjava.util.concurrentJava SE
ConcurrentHashMapA hash table supporting full concurrency of retrievals and high expected concurrency for updates.Classjava.util.concurrentJava SE
ConcurrentHashMap .KeySetViewA view of a ConcurrentHashMap as a Set of keys, in which additions may optionally be enabled by mapping to aClassjava.util.concurrent.ConcurrentHashMapJava SE
ConcurrentLinkedDequeAn unbounded concurrent deque based on linked nodes.Classjava.util.concurrentJava SE
ConcurrentLinkedQueueAn unbounded thread-safe queue based on linked nodes.Classjava.util.concurrentJava SE
ConcurrentModificationExceptionThis exception may be thrown by methods that have detected concurrent modification of an object when such modification is not permissible.Classjava.utilJava SE
ConcurrentSkipListMapA scalable concurrent ConcurrentNavigableMap implementation.Classjava.util.concurrentJava SE
ConcurrentSkipListSetA scalable concurrent NavigableSet implementation based on a ConcurrentSkipListMap.Classjava.util.concurrentJava SE
ConsoleHandlerThis Handler publishes log records to System.Classjava.util.loggingJava SE
CopyOnWriteArrayListA thread-safe variant of ArrayList in which all mutative operations (add, set, and so on) are implemented byClassjava.util.concurrentJava SE
CopyOnWriteArraySetA Set that uses an internal CopyOnWriteArrayList for all of its operations.Classjava.util.concurrentJava SE
CountDownLatchA synchronization aid that allows one or more threads to wait until a set of operations being performed in other threads completes.Classjava.util.concurrentJava SE
CountedCompleterA ForkJoinTask with a completion action performed when triggered and there are no remaining pending actions.Classjava.util.concurrentJava SE
CRC32A class that can be used to compute the CRC-32 of a data stream.Classjava.util.zipJava SE
CRC32CA class that can be used to compute the CRC-32C of a data stream.Classjava.util.zipJava SE
CurrencyRepresents a currency.Classjava.utilJava SE
CurrencyNameProviderAn abstract class for service providers that provide localized currency symbols and display names for theClassjava.util.spiJava SE
CyclicBarrierA synchronization aid that allows a set of threads to all wait for each other to reach a common barrier point.Classjava.util.concurrentJava SE
Collector .CharacteristicsCharacteristics indicating properties of a Collector, which can be used to optimize reduction implementations.Classjava.util.stream.CollectorJava SE
CallableA task that returns a result and may throw an exception.Interfacejava.util.concurrentJava SE
ChecksumAn interface representing a data checksum.Interfacejava.util.zipJava SE
CollectionThe root interface in the collection hierarchy.Interfacejava.utilJava SE
CollectorInterfacejava.util.streamJava SE
ComparatorA comparison function, which imposes a total ordering on some collection of objects.Interfacejava.utilJava SE
CompletableFuture .AsynchronousCompletionTaskA marker interface identifying asynchronous tasks produced by async methods.Interfacejava.util.concurrent.CompletableFutureJava SE
CompletionServiceA service that decouples the production of new asynchronous tasks from the consumption of the results of completed tasks.Interfacejava.util.concurrentJava SE
CompletionStageA stage of a possibly asynchronous computation, that performs an action or computes a value when another CompletionStage completes.Interfacejava.util.concurrentJava SE
ConcurrentMapA Map providing thread safety and atomicity To maintain the specified guarantees, default implementations ofInterfacejava.util.concurrentJava SE
ConcurrentNavigableMapA ConcurrentMap supporting NavigableMap operations, and recursively so for its navigable sub-maps.Interfacejava.util.concurrentJava SE
ConditionCondition factors out the Object monitor methods (wait, notifyInterfacejava.util.concurrent.locksJava SE
ConsumerRepresents an operation that accepts a single input argument and returns no result.Interfacejava.util.functionJava SE
DataFormatExceptionSignals that a data format error has occurred.Classjava.util.zipJava SE
DateThe class Date represents a specific instant in time, with millisecond precision.Classjava.utilJava SE
DeflaterThis class provides support for general purpose compression using the popular ZLIB compression library.Classjava.util.zipJava SE
DeflaterInputStream compression format.Classjava.util.zipJava SE
DeflaterOutputStreamThis class implements an output stream filter for compressing data in the deflate compression format.Classjava.util.zipJava SE
DelayQueueAn unbounded blocking queue of Delayed elements, in which an element can only be takenClassjava.util.concurrentJava SE
DictionaryThe Dictionary class is the abstract parent of any class, such as Hashtable, which maps keys to values.Classjava.utilJava SE
DoubleAccumulatorOne or more variables that together maintain a running double value updated using a supplied function.Classjava.util.concurrent.atomicJava SE
DoubleAdderOne or more variables that together maintain an initially zero double sum.Classjava.util.concurrent.atomicJava SE
DoubleSummaryStatisticsA state object for collecting statistics such as count, min, max, sum, and This class is designed to work with (though does not require)Classjava.utilJava SE
DuplicateFormatFlagsExceptionUnchecked exception thrown when duplicate flags are provided in the format Unless otherwise specified, passing a null argument to anyClassjava.utilJava SE
DelayedA mix-in style interface for marking objects that should be acted upon after a given delay.Interfacejava.util.concurrentJava SE
DequeA linear collection that supports element insertion and removal at both ends.Interfacejava.utilJava SE
DoubleBinaryOperatorRepresents an operation upon two double-valued operands and producing a double-valued result.Interfacejava.util.functionJava SE
DoubleConsumerRepresents an operation that accepts a single double-valued argument and returns no result.Interfacejava.util.functionJava SE
DoubleFunctionRepresents a function that accepts a double-valued argument and produces a result.Interfacejava.util.functionJava SE
DoublePredicateRepresents a predicate (boolean-valued function) of one double-valued argument.Interfacejava.util.functionJava SE
DoubleStreamA sequence of primitive double-valued elements supporting sequential and parallel aggregate operations.Interfacejava.util.streamJava SE
DoubleStream .BuilderA mutable builder for a DoubleStream.Interfacejava.util.stream.DoubleStreamJava SE
DoubleSupplierRepresents a supplier of double-valued results.Interfacejava.util.functionJava SE
DoubleToIntFunctionRepresents a function that accepts a double-valued argument and produces an int-valued result.Interfacejava.util.functionJava SE
DoubleToLongFunctionRepresents a function that accepts a double-valued argument and produces a long-valued result.Interfacejava.util.functionJava SE
DoubleUnaryOperatorRepresents an operation on a single double-valued operand that produces a double-valued result.Interfacejava.util.functionJava SE
EmptyStackExceptionThrown by methods in the Stack class to indicate that the stack is empty.Classjava.utilJava SE
EnumMapA specialized Map implementation for use with enum type keys.Classjava.utilJava SE
EnumSetA specialized Set implementation for use with enum types.Classjava.utilJava SE
ErrorManagerErrorManager objects can be attached to Handlers to process any error that occurs on a Handler during Logging.Classjava.util.loggingJava SE
EventListenerProxyAn abstract wrapper class for an EventListener class which associates a set of additional parameters with the listener.Classjava.utilJava SE
EventObject The root class from which all event state objects shall be derived.Classjava.utilJava SE
ExchangerA synchronization point at which threads can pair and swap elements within pairs.Classjava.util.concurrentJava SE
ExecutionExceptionException thrown when attempting to retrieve the result of a task that aborted by throwing an exception.Classjava.util.concurrentJava SE
ExecutorCompletionServiceA CompletionService that uses a supplied Executor to execute tasks.Classjava.util.concurrentJava SE
ExecutorsFactory and utility methods for Executor, ExecutorService, ScheduledExecutorService, ThreadFactory, and Callable classes defined in this package.Classjava.util.concurrentJava SE
EnumerationAn object that implements the Enumeration interface generates a series of elements, one at a time.Interfacejava.utilJava SE
EventListenerA tagging interface that all event listener interfaces must extend.Interfacejava.utilJava SE
ExecutorAn object that executes submitted Runnable tasks.Interfacejava.util.concurrentJava SE
ExecutorServiceAn Executor that provides methods to manage termination and methods that can produce a Future for tracking progress ofInterfacejava.util.concurrentJava SE
FileHandlerSimple file logging Handler.Classjava.util.loggingJava SE
FlowInterrelated interfaces and static methods for establishing flow-controlled components in which PublishersClassjava.util.concurrentJava SE
ForkJoinPoolAn ExecutorService for running ForkJoinTasks.Classjava.util.concurrentJava SE
ForkJoinTaskAbstract base class for tasks that run within a ForkJoinPool.Classjava.util.concurrentJava SE
ForkJoinWorkerThreadA thread managed by a ForkJoinPool, which executes This class is subclassable solely for the sake of addingClassjava.util.concurrentJava SE
FormatFlagsConversionMismatchExceptionUnchecked exception thrown when a conversion and flag are incompatible.Classjava.utilJava SE
FormattableFlagsFomattableFlags are passed to the Formattable.Classjava.utilJava SE
FormatterAn interpreter for printf-style format strings.Classjava.utilJava SE
FormatterA Formatter provides support for formatting LogRecords.Classjava.util.loggingJava SE
FormatterClosedExceptionUnchecked exception thrown when the formatter has been closed.Classjava.utilJava SE
FutureTaskA cancellable asynchronous computation.Classjava.util.concurrentJava SE
Formatter .BigDecimalLayoutFormFormat the BigDecimal as a decimal number.Classjava.util.FormatterJava SE
FilterA Filter can be used to provide fine grain control over what is logged, beyond the control provided by log levels.Interfacejava.util.loggingJava SE
Flow .ProcessorA component that acts as both a Subscriber and Publisher.Interfacejava.util.concurrent.FlowJava SE
Flow .PublisherA producer of items (and related control messages) received by Subscribers.Interfacejava.util.concurrent.FlowJava SE
Flow .SubscriberA receiver of messages.Interfacejava.util.concurrent.FlowJava SE
Flow .SubscriptionMessage control linking a Flow.Interfacejava.util.concurrent.FlowJava SE
ForkJoinPool .ForkJoinWorkerThreadFactoryFactory for creating new ForkJoinWorkerThreads.Interfacejava.util.concurrent.ForkJoinPoolJava SE
ForkJoinPool .ManagedBlocker A ManagedBlocker provides two methods.Interfacejava.util.concurrent.ForkJoinPoolJava SE
FormattableThe Formattable interface must be implemented by any class that needs to perform custom formatting using the 's' conversionInterfacejava.utilJava SE
FunctionRepresents a function that accepts one argument and produces a result.Interfacejava.util.functionJava SE
FutureA Future represents the result of an asynchronous computation.Interfacejava.util.concurrentJava SE
GregorianCalendarGregorianCalendar is a concrete subclass of Calendar and provides the standard calendar systemClassjava.utilJava SE
GZIPInputStreamThis class implements a stream filter for reading compressed data in the GZIP file format.Classjava.util.zipJava SE
GZIPOutputStreamThis class implements a stream filter for writing compressed data in the GZIP file format.Classjava.util.zipJava SE
HandlerA Handler object takes log messages from a Logger and exports them.Classjava.util.loggingJava SE
HashMapHash table based implementation of the Map interface.Classjava.utilJava SE
HashSetThis class implements the Set interface, backed by a hash table (actually a HashMap instance).Classjava.utilJava SE
HashtableThis class implements a hash table, which maps keys to values.Classjava.utilJava SE
IdentityHashMapThis class implements the Map interface with a hash table, using reference-equality in place of object-equality when comparing keys (andClassjava.utilJava SE
IllegalFormatCodePointExceptionUnchecked exception thrown when a character with an invalid Unicode code point as defined by Character.Classjava.utilJava SE
IllegalFormatConversionExceptionUnchecked exception thrown when the argument corresponding to the format specifier is of an incompatible type.Classjava.utilJava SE
IllegalFormatExceptionUnchecked exception thrown when a format string contains an illegal syntax or a format specifier that is incompatible with the given arguments.Classjava.utilJava SE
IllegalFormatFlagsExceptionUnchecked exception thrown when an illegal combination flags is given.Classjava.utilJava SE
IllegalFormatPrecisionExceptionUnchecked exception thrown when the precision is a negative value other than -1, the conversion does not support a precision, or the value isClassjava.utilJava SE
IllegalFormatWidthExceptionUnchecked exception thrown when the format width is a negative value other than -1 or is otherwise unsupported.Classjava.utilJava SE
IllformedLocaleExceptionThrown by methods in Locale and Locale.Classjava.utilJava SE
InflaterThis class provides support for general purpose decompression using the popular ZLIB compression library.Classjava.util.zipJava SE
InflaterInputStreamThis class implements a stream filter for uncompressing data in the deflate compression format.Classjava.util.zipJava SE
InflaterOutputStream deflate compression format.Classjava.util.zipJava SE
InputMismatchExceptionThrown by a Scanner to indicate that the token retrieved does not match the pattern for the expected type, orClassjava.utilJava SE
IntSummaryStatisticsA state object for collecting statistics such as count, min, max, sum, and This class is designed to work with (though does not require)Classjava.utilJava SE
InvalidPreferencesFormatExceptionThrown to indicate that an operation could not complete because the input did not conform to the appropriate XML document typeClassjava.util.prefsJava SE
InvalidPropertiesFormatExceptionThrown to indicate that an operation could not complete because the input did not conform to the appropriate XML document typeClassjava.utilJava SE
IntBinaryOperatorRepresents an operation upon two int-valued operands and producing an int-valued result.Interfacejava.util.functionJava SE
IntConsumerRepresents an operation that accepts a single int-valued argument and returns no result.Interfacejava.util.functionJava SE
IntFunctionRepresents a function that accepts an int-valued argument and produces a result.Interfacejava.util.functionJava SE
IntPredicateRepresents a predicate (boolean-valued function) of one int-valued argument.Interfacejava.util.functionJava SE
IntStreamA sequence of primitive int-valued elements supporting sequential and parallel aggregate operations.Interfacejava.util.streamJava SE
IntStream .BuilderA mutable builder for an IntStream.Interfacejava.util.stream.IntStreamJava SE
IntSupplierRepresents a supplier of int-valued results.Interfacejava.util.functionJava SE
IntToDoubleFunctionRepresents a function that accepts an int-valued argument and produces a double-valued result.Interfacejava.util.functionJava SE
IntToLongFunctionRepresents a function that accepts an int-valued argument and produces a long-valued result.Interfacejava.util.functionJava SE
IntUnaryOperatorRepresents an operation on a single int-valued operand that produces an int-valued result.Interfacejava.util.functionJava SE
IteratorAn iterator over a collection.Interfacejava.utilJava SE
JarEntryThis class is used to represent a JAR file entry.Classjava.util.jarJava SE
JarExceptionSignals that an error of some sort has occurred while reading from or writing to a JAR file.Classjava.util.jarJava SE
JarFileThe JarFile class is used to read the contents of a jar file from any file that can be opened with java.Classjava.util.jarJava SE
JarInputStreamThe JarInputStream class is used to read the contents of a JAR file from any input stream.Classjava.util.jarJava SE
JarOutputStreamThe JarOutputStream class is used to write the contents of a JAR file to any output stream.Classjava.util.jarJava SE
LevelThe Level class defines a set of standard logging levels that can be used to control logging output.Classjava.util.loggingJava SE
LinkedBlockingDequeAn optionally-bounded blocking deque based on The optional capacity bound constructor argument serves as aClassjava.util.concurrentJava SE
LinkedBlockingQueueAn optionally-bounded blocking queue based on This queue orders elements FIFO (first-in-first-out).Classjava.util.concurrentJava SE
LinkedHashMapHash table and linked list implementation of the Map interface, with predictable iteration order.Classjava.utilJava SE
LinkedHashSetHash table and linked list implementation of the Set interface, with predictable iteration order.Classjava.utilJava SE
LinkedListDoubly-linked list implementation of the List and Deque interfaces.Classjava.utilJava SE
LinkedTransferQueueAn unbounded TransferQueue based on linked nodes.Classjava.util.concurrentJava SE
ListResourceBundleListResourceBundle is an abstract subclass of ResourceBundle that manages resources for a localeClassjava.utilJava SE
LocaleA Locale object represents a specific geographical, political, or cultural region.Classjava.utilJava SE
Locale .BuilderBuilder is used to build instances of Locale from values configured by the setters.Classjava.util.LocaleJava SE
Locale .LanguageRangeThis class expresses a Language Range defined in RFC 4647 Matching ofClassjava.util.LocaleJava SE
LocaleNameProviderAn abstract class for service providers that provide localized names for theClassjava.util.spiJava SE
LocaleServiceProvider This is the super class of all the locale sensitive service provider Locale sensitive service provider interfaces are interfaces thatClassjava.util.spiJava SE
LockSupportBasic thread blocking primitives for creating locks and other synchronization classes.Classjava.util.concurrent.locksJava SE
LoggerA Logger object is used to log messages for a specific system or application component.Classjava.util.loggingJava SE
LoggingPermissionThe permission which the SecurityManager will check when code that is running with a SecurityManager calls one of the loggingClassjava.util.loggingJava SE
LogManagerThere is a single global LogManager object that is used to maintain a set of shared state about Loggers and log services.Classjava.util.loggingJava SE
LogRecordLogRecord objects are used to pass logging requests between the logging framework and individual log Handlers.Classjava.util.loggingJava SE
LongAccumulatorOne or more variables that together maintain a running long value updated using a supplied function.Classjava.util.concurrent.atomicJava SE
LongAdderOne or more variables that together maintain an initially zero long sum.Classjava.util.concurrent.atomicJava SE
LongSummaryStatisticsA state object for collecting statistics such as count, min, max, sum, and This class is designed to work with (though does not require)Classjava.utilJava SE
Locale .Category the default locale for the specific functionality represented by theSince:1.Classjava.util.LocaleJava SE
Locale .FilteringModeThis enum provides constants to select a filtering mode for locale matching.Classjava.util.LocaleJava SE
ListAn ordered collection (also known as a sequence).Interfacejava.utilJava SE
ListIteratorAn iterator for lists that allows the programmer to traverse the list in either direction, modifyInterfacejava.utilJava SE
LockLock implementations provide more extensive locking operations than can be obtained using synchronized methodsInterfacejava.util.concurrent.locksJava SE
LoggingMXBeanThe management interface for the logging facility.Interfacejava.util.loggingJava SE
LongBinaryOperatorRepresents an operation upon two long-valued operands and producing a long-valued result.Interfacejava.util.functionJava SE
LongConsumerRepresents an operation that accepts a single long-valued argument and returns no result.Interfacejava.util.functionJava SE
LongFunctionRepresents a function that accepts a long-valued argument and produces a result.Interfacejava.util.functionJava SE
LongPredicateRepresents a predicate (boolean-valued function) of one long-valued argument.Interfacejava.util.functionJava SE
LongStreamA sequence of primitive long-valued elements supporting sequential and parallel aggregate operations.Interfacejava.util.streamJava SE
LongStream .BuilderA mutable builder for a LongStream.Interfacejava.util.stream.LongStreamJava SE
LongSupplierRepresents a supplier of long-valued results.Interfacejava.util.functionJava SE
LongToDoubleFunctionRepresents a function that accepts a long-valued argument and produces a double-valued result.Interfacejava.util.functionJava SE
LongToIntFunctionRepresents a function that accepts a long-valued argument and produces an int-valued result.Interfacejava.util.functionJava SE
LongUnaryOperatorRepresents an operation on a single long-valued operand that produces a long-valued result.Interfacejava.util.functionJava SE
ManifestThe Manifest class is used to maintain Manifest entry names and their associated Attributes.Classjava.util.jarJava SE
MatcherAn engine that performs match operations on a character sequence by interpreting a Pattern.Classjava.util.regexJava SE
MemoryHandlerHandler that buffers requests in a circular buffer in memory.Classjava.util.loggingJava SE
MissingFormatArgumentExceptionUnchecked exception thrown when there is a format specifier which does not have a corresponding argument or if an argument index refers to an argumentClassjava.utilJava SE
MissingFormatWidthExceptionUnchecked exception thrown when the format width is required.Classjava.utilJava SE
MissingResourceExceptionSignals that a resource is missing.Classjava.utilJava SE
MapAn object that maps keys to values.Interfacejava.utilJava SE
Map .EntryA map entry (key-value pair).Interfacejava.util.MapJava SE
MatchResultThe result of a match operation.Interfacejava.util.regexJava SE
NodeChangeEventAn event emitted by a Preferences node to indicate that a child of that node has been added or removed.Classjava.util.prefsJava SE
NoSuchElementExceptionThrown by various accessor methods to indicate that the element being requestedSince:1.Classjava.utilJava SE
NavigableMapA SortedMap extended with navigation methods returning the closest matches for given search targets.Interfacejava.utilJava SE
NavigableSetA SortedSet extended with navigation methods reporting closest matches for given search targets.Interfacejava.utilJava SE
NodeChangeListenerA listener for receiving preference node change events.Interfacejava.util.prefsJava SE
ObjectsThis class consists of static utility methods for operating on objects, or checking certain conditions before operation.Classjava.utilJava SE
ObservableThis class represents an observable object, or data in the model-view paradigm.Classjava.utilJava SE
OptionalA container object which may or may not contain a non-null value.Classjava.utilJava SE
OptionalDoubleA container object which may or may not contain a double value.Classjava.utilJava SE
OptionalIntA container object which may or may not contain an int value.Classjava.utilJava SE
OptionalLongA container object which may or may not contain a long value.Classjava.utilJava SE
ObjDoubleConsumerRepresents an operation that accepts an object-valued and a double-valued argument, and returns no result.Interfacejava.util.functionJava SE
ObjIntConsumerRepresents an operation that accepts an object-valued and a int-valued argument, and returns no result.Interfacejava.util.functionJava SE
ObjLongConsumerRepresents an operation that accepts an object-valued and a long-valued argument, and returns no result.Interfacejava.util.functionJava SE
ObserverA class can implement the Observer interface when it wants to be informed of changes in observable objects.Interfacejava.utilJava SE
Pack200Transforms a JAR file to or from a packed stream in Pack200 format.Classjava.util.jarJava SE
PatternA compiled representation of a regular expression.Classjava.util.regexJava SE
PatternSyntaxExceptionUnchecked exception thrown to indicate a syntax error in a regular-expression pattern.Classjava.util.regexJava SE
PhaserA reusable synchronization barrier, similar in functionality to but supporting more flexible usage.Classjava.util.concurrentJava SE
PreferenceChangeEventAn event emitted by a Preferences node to indicate that a preference has been added, removed or has had its value changed.Classjava.util.prefsJava SE
PreferencesA node in a hierarchical collection of preference data.Classjava.util.prefsJava SE
PriorityBlockingQueueAn unbounded blocking queue that uses the same ordering rules as class PriorityQueue and suppliesClassjava.util.concurrentJava SE
PriorityQueueAn unbounded priority queue based on a priority heap.Classjava.utilJava SE
PropertiesThe Properties class represents a persistent set of properties.Classjava.utilJava SE
PropertyPermissionThis class is for property permissions.Classjava.utilJava SE
PropertyResourceBundlePropertyResourceBundle is a concrete subclass of ResourceBundle that manages resources for a localeClassjava.utilJava SE
Pack200 .PackerThe packer engine applies various transformations to the input JAR file, making the pack stream highly compressible by a compressor such asInterfacejava.util.jar.Pack200Java SE
Pack200 .UnpackerThe unpacker engine converts the packed stream to a JAR file.Interfacejava.util.jar.Pack200Java SE
PredicateRepresents a predicate (boolean-valued function) of one argument.Interfacejava.util.functionJava SE
PreferenceChangeListenerA listener for receiving preference change events.Interfacejava.util.prefsJava SE
PreferencesFactoryA factory object that generates Preferences objects.Interfacejava.util.prefsJava SE
PrimitiveIteratorA base type for primitive specializations of Iterator.Interfacejava.utilJava SE
PrimitiveIterator .OfDoubleAn Iterator specialized for double values.Interfacejava.util.PrimitiveIteratorJava SE
PrimitiveIterator .OfIntAn Iterator specialized for int values.Interfacejava.util.PrimitiveIteratorJava SE
PrimitiveIterator .OfLongAn Iterator specialized for long values.Interfacejava.util.PrimitiveIteratorJava SE
QueueA collection designed for holding elements prior to processing.Interfacejava.utilJava SE
RandomAn instance of this class is used to generate a stream of pseudorandom numbers.Classjava.utilJava SE
RecursiveActionA recursive resultless ForkJoinTask.Classjava.util.concurrentJava SE
RecursiveTaskA recursive result-bearing ForkJoinTask.Classjava.util.concurrentJava SE
ReentrantLockA reentrant mutual exclusion Lock with the same basic behavior and semantics as the implicit monitor lock accessed usingClassjava.util.concurrent.locksJava SE
ReentrantReadWriteLockAn implementation of ReadWriteLock supporting similar semantics to ReentrantLock.Classjava.util.concurrent.locksJava SE
ReentrantReadWriteLock .ReadLockThe lock returned by method ReentrantReadWriteLock.Classjava.util.concurrent.locks.ReentrantReadWriteLockJava SE
ReentrantReadWriteLock .WriteLockThe lock returned by method ReentrantReadWriteLock.Classjava.util.concurrent.locks.ReentrantReadWriteLockJava SE
RejectedExecutionExceptionException thrown by an Executor when a task cannot be accepted for execution.Classjava.util.concurrentJava SE
ResourceBundleResource bundles contain locale-specific objects.Classjava.utilJava SE
ResourceBundle .ControlResourceBundle.Classjava.util.ResourceBundleJava SE
RandomAccessMarker interface used by List implementations to indicate that they support fast (generally constant time) random access.Interfacejava.utilJava SE
ReadWriteLockA ReadWriteLock maintains a pair of associated locks, one for read-only operations and one for writing.Interfacejava.util.concurrent.locksJava SE
RejectedExecutionHandlerA handler for tasks that cannot be executed by a ThreadPoolExecutor.Interfacejava.util.concurrentJava SE
ResourceBundleControlProviderAn interface for service providers that provide implementations of ResourceBundle.Interfacejava.util.spiJava SE
RunnableFutureA Future that is Runnable.Interfacejava.util.concurrentJava SE
RunnableScheduledFutureA ScheduledFuture that is Runnable.Interfacejava.util.concurrentJava SE
ScannerA simple text scanner which can parse primitive types and strings using regular expressions.Classjava.utilJava SE
ScheduledThreadPoolExecutorA ThreadPoolExecutor that can additionally schedule commands to run after a given delay, or to execute periodically.Classjava.util.concurrentJava SE
SemaphoreA counting semaphore.Classjava.util.concurrentJava SE
ServiceConfigurationErrorError thrown when something goes wrong while loading a service provider.Classjava.utilJava SE
ServiceLoaderA simple service-provider loading facility.Classjava.utilJava SE
SimpleFormatterPrint a brief summary of the LogRecord in a human readable format.Classjava.util.loggingJava SE
SimpleTimeZoneSimpleTimeZone is a concrete subclass of TimeZone that represents a time zone for use with a Gregorian calendar.Classjava.utilJava SE
SocketHandlerSimple network logging Handler.Classjava.util.loggingJava SE
SpliteratorsStatic classes and methods for operating on or creating instances of Spliterator and its primitive specializationsClassjava.utilJava SE
Spliterators .AbstractDoubleSpliteratorAn abstract Spliterator.Classjava.util.SpliteratorsJava SE
Spliterators .AbstractIntSpliteratorAn abstract Spliterator.Classjava.util.SpliteratorsJava SE
Spliterators .AbstractLongSpliteratorAn abstract Spliterator.Classjava.util.SpliteratorsJava SE
Spliterators .AbstractSpliteratorAn abstract Spliterator that implements trySplit to permit limited parallelism.Classjava.util.SpliteratorsJava SE
SplittableRandomA generator of uniform pseudorandom values applicable for use in (among other contexts) isolated parallel computations that mayClassjava.utilJava SE
StackThe Stack class represents a last-in-first-out (LIFO) stack of objects.Classjava.utilJava SE
StampedLockA capability-based lock with three modes for controlling read/write access.Classjava.util.concurrent.locksJava SE
StreamHandlerStream based logging Handler.Classjava.util.loggingJava SE
StreamSupportLow-level utility methods for creating and manipulating streams.Classjava.util.streamJava SE
StringJoinerStringJoiner is used to construct a sequence of characters separated by a delimiter and optionally starting with a supplied prefixClassjava.utilJava SE
StringTokenizerThe string tokenizer class allows an application to break a string into tokens.Classjava.utilJava SE
SubmissionPublisherA Flow.Classjava.util.concurrentJava SE
SynchronousQueueA blocking queue in which each insert operation must wait for a corresponding remove operation by anotherClassjava.util.concurrentJava SE
ScheduledExecutorServiceAn ExecutorService that can schedule commands to run after a given delay, or to execute periodically.Interfacejava.util.concurrentJava SE
ScheduledFutureA delayed result-bearing action that can be cancelled.Interfacejava.util.concurrentJava SE
SetA collection that contains no duplicate elements.Interfacejava.utilJava SE
SortedMapA Map that further provides a total ordering on its keys.Interfacejava.utilJava SE
SortedSetA Set that further provides a total ordering on its elements.Interfacejava.utilJava SE
SpliteratorAn object for traversing and partitioning elements of a source.Interfacejava.utilJava SE
Spliterator .OfDoubleA Spliterator specialized for double values.Interfacejava.util.SpliteratorJava SE
Spliterator .OfIntA Spliterator specialized for int values.Interfacejava.util.SpliteratorJava SE
Spliterator .OfLongA Spliterator specialized for long values.Interfacejava.util.SpliteratorJava SE
Spliterator .OfPrimitiveA Spliterator specialized for primitive values.Interfacejava.util.SpliteratorJava SE
StreamA sequence of elements supporting sequential and parallel aggregate operations.Interfacejava.util.streamJava SE
Stream .BuilderA mutable builder for a Stream.Interfacejava.util.stream.StreamJava SE
SupplierRepresents a supplier of results.Interfacejava.util.functionJava SE
ThreadLocalRandomA random number generator isolated to the current thread.Classjava.util.concurrentJava SE
ThreadPoolExecutorAn ExecutorService that executes each submitted task using one of possibly several pooled threads, normally configuredClassjava.util.concurrentJava SE
ThreadPoolExecutor .AbortPolicyA handler for rejected tasks that throws a RejectedExecutionException.Classjava.util.concurrent.ThreadPoolExecutorJava SE
ThreadPoolExecutor .CallerRunsPolicyA handler for rejected tasks that runs the rejected task directly in the calling thread of the execute method,Classjava.util.concurrent.ThreadPoolExecutorJava SE
ThreadPoolExecutor .DiscardOldestPolicyA handler for rejected tasks that discards the oldest unhandled request and then retries execute, unless the executorClassjava.util.concurrent.ThreadPoolExecutorJava SE
ThreadPoolExecutor .DiscardPolicyClassjava.util.concurrent.ThreadPoolExecutorJava SE
TimeoutExceptionException thrown when a blocking operation times out.Classjava.util.concurrentJava SE
TimerA facility for threads to schedule tasks for future execution in a background thread.Classjava.utilJava SE
TimerTaskA task that can be scheduled for one-time or repeated execution by a A timer task is not reusable.Classjava.utilJava SE
TimeZoneTimeZone represents a time zone offset, and also figures out daylight Typically, you get a TimeZone using getDefaultClassjava.utilJava SE
TimeZoneNameProviderAn abstract class for service providers that provide localized time zone names for theClassjava.util.spiJava SE
TooManyListenersException The TooManyListenersException Exception is used as part of the Java Event model to annotate and implement a unicast special case ofClassjava.utilJava SE
TreeMapA Red-Black tree based NavigableMap implementation.Classjava.utilJava SE
TreeSetA NavigableSet implementation based on a TreeMap.Classjava.utilJava SE
TimeUnitA TimeUnit represents time durations at a given unit of granularity and provides utility methods to convert across units,Classjava.util.concurrentJava SE
ThreadFactoryAn object that creates new threads on demand.Interfacejava.util.concurrentJava SE
ToDoubleBiFunctionRepresents a function that accepts two arguments and produces a double-valued result.Interfacejava.util.functionJava SE
ToDoubleFunctionRepresents a function that produces a double-valued result.Interfacejava.util.functionJava SE
ToIntBiFunctionRepresents a function that accepts two arguments and produces an int-valued result.Interfacejava.util.functionJava SE
ToIntFunctionRepresents a function that produces an int-valued result.Interfacejava.util.functionJava SE
ToLongBiFunctionRepresents a function that accepts two arguments and produces a long-valued result.Interfacejava.util.functionJava SE
ToLongFunctionRepresents a function that produces a long-valued result.Interfacejava.util.functionJava SE
TransferQueueA BlockingQueue in which producers may wait for consumers to receive elements.Interfacejava.util.concurrentJava SE
UnknownFormatConversionExceptionUnchecked exception thrown when an unknown conversion is given.Classjava.utilJava SE
UnknownFormatFlagsExceptionUnchecked exception thrown when an unknown flag is given.Classjava.utilJava SE
UUIDA class that represents an immutable universally unique identifier (UUID).Classjava.utilJava SE
UnaryOperatorRepresents an operation on a single operand that produces a result of the same type as its operand.Interfacejava.util.functionJava SE
VectorThe Vector class implements a growable array of objects.Classjava.utilJava SE
WeakHashMapHash table based implementation of the Map interface, with An entry in a WeakHashMap will automatically be removed whenClassjava.utilJava SE
XMLFormatterFormat a LogRecord into a standard XML format.Classjava.util.loggingJava SE
ZipEntryThis class is used to represent a ZIP file entry.Classjava.util.zipJava SE
ZipErrorSignals that an unrecoverable error has occurred.Classjava.util.zipJava SE
ZipExceptionSignals that a Zip exception of some sort has occurred.Classjava.util.zipJava SE
ZipFileThis class is used to read entries from a zip file.Classjava.util.zipJava SE
ZipInputStreamThis class implements an input stream filter for reading files in the ZIP file format.Classjava.util.zipJava SE
ZipOutputStreamThis class implements an output stream filter for writing files in the ZIP file format.Classjava.util.zipJava SE
AdaptiveCodingClasssun.java.util.jar.packCode Trails
AttributeClasssun.java.util.jar.packCode Trails
Attribute .FormatExceptionClasssun.java.util.jar.pack.AttributeCode Trails
Attribute .HolderBase class for any attributed object (Class, Field, Method, Code).Classsun.java.util.jar.pack.AttributeCode Trails
Attribute .LayoutA "class" of attributes, characterized by a context-type, name and format.Classsun.java.util.jar.pack.AttributeCode Trails
Attribute .ValueStreamClasssun.java.util.jar.pack.AttributeCode Trails
BandStructureClasssun.java.util.jar.packCode Trails
BandStructure .ByteCounterAn output stream which counts the number of bytes written.Classsun.java.util.jar.pack.BandStructureCode Trails
ClassReaderClasssun.java.util.jar.packCode Trails
ClassReader .ClassFormatExceptionClasssun.java.util.jar.pack.ClassReaderCode Trails
ClassWriterClasssun.java.util.jar.packCode Trails
CodeClasssun.java.util.jar.packCode Trails
CodingClasssun.java.util.jar.packCode Trails
CodingChooserClasssun.java.util.jar.packCode Trails
CodingChooser .ChoiceClasssun.java.util.jar.pack.CodingChooserCode Trails
CodingChooser .SizerClasssun.java.util.jar.pack.CodingChooserCode Trails
CodingMethodInterfacesun.java.util.jar.packCode Trails
ConstantPoolClasssun.java.util.jar.packCode Trails
ConstantPool .ClassEntryClasssun.java.util.jar.pack.ConstantPoolCode Trails
ConstantPool .DescriptorEntryClasssun.java.util.jar.pack.ConstantPoolCode Trails
ConstantPool .EntryEntries in the constant pool.Classsun.java.util.jar.pack.ConstantPoolCode Trails
ConstantPool .IndexAn Index is a mapping between CP entries and small integers.Classsun.java.util.jar.pack.ConstantPoolCode Trails
ConstantPool .IndexGroupCoherent group of constant pool indexes.Classsun.java.util.jar.pack.ConstantPoolCode Trails
ConstantPool .LiteralEntryClasssun.java.util.jar.pack.ConstantPoolCode Trails
ConstantPool .MemberEntryClasssun.java.util.jar.pack.ConstantPoolCode Trails
ConstantPool .NumberEntryClasssun.java.util.jar.pack.ConstantPoolCode Trails
ConstantPool .SignatureEntryClasssun.java.util.jar.pack.ConstantPoolCode Trails
ConstantPool .StringEntryClasssun.java.util.jar.pack.ConstantPoolCode Trails
ConstantPool .Utf8EntryClasssun.java.util.jar.pack.ConstantPoolCode Trails
ConstantsClasssun.java.util.jar.packCode Trails
CalendarCalendar is an abstract base class for converting between a Date object and a set of integer fields such asClassjava.utilJava ME
DateThe class Date represents a specific instant in time, with millisecond This class has been subset for the J2ME based on the JDK 1.Classjava.utilJava ME
EmptyStackExceptionThrown by methods in the Stack class to indicate that the stack is empty.Classjava.utilJava ME
EnumerationAn object that implements the Enumeration interface generates a series of elements, one at a time.Interfacejava.utilJava ME
HashtableThis class implements a hashtable, which maps keys to values.Classjava.utilJava ME
NoSuchElementExceptionThrown by the nextElement method of an Enumeration to indicate that there are no more Classjava.utilJava ME
RandomAn instance of this class is used to generate a stream of pseudorandom numbers.Classjava.utilJava ME
StackThe Stack class represents a last-in-first-out (LIFO) stack of objects.Classjava.utilJava ME
TimeZoneTimeZone represents a time zone offset, and also figures out daylight savings.Classjava.utilJava ME
TimerA facility for threads to schedule tasks for future execution in a background thread.Classjava.utilJava ME
TimerTaskA task that can be scheduled for one-time or repeated execution by aSince:1.Classjava.utilJava ME
VectorThe Vector class implements a growable array of objects.Classjava.utilJava ME
UtilsClassorg.apache.axis.wsdl.toJavaApache Axis
AbstractCollection modifiable collection it's necessary to override the add() method that currently throws an UnsupportedOperationException.Classjava.utilCodeName One
AbstractListAbstractList is an abstract implementation of the List interface, optimized for a backing store which supports random access.Classjava.utilCodeName One
AbstractMapThis class is an abstract implementation of the Map interface.Classjava.utilCodeName One
AbstractMap .SimpleEntryA key-value mapping.Classjava.util.AbstractMapCodeName One
AbstractMap .SimpleImmutableEntryAn immutable key-value mapping.Classjava.util.AbstractMapCodeName One
AbstractQueueAbstractQueue is an abstract class which implements some of the methods in Queue.Classjava.utilCodeName One
AbstractSequentialListAbstractSequentialList is an abstract implementation of the List interface.Classjava.utilCodeName One
AbstractSetAn AbstractSet is an abstract implementation of the Set interface.Classjava.utilCodeName One
ArrayDequeAn implementation of Deque, backed by an array.Classjava.utilCodeName One
ArrayListArrayList is an implementation of List, backed by an array.Classjava.utilCodeName One
ArraysArrays contains static methods which operate on arrays.Classjava.utilCodeName One
BitSetThe BitSet class implements a bit field.Classjava.utilCodeName One
CalendarCalendar is an abstract base class for converting between a Date object and a set of integer fields such as YEAR, MONTH, DAY, HOUR, and so on.Classjava.utilCodeName One
CollectionCollection is the root of the collection hierarchy.Interfacejava.utilCodeName One
CollectionsCollections contains static methods which operate on Collection classes.Classjava.utilCodeName One
ComparatorA Comparator is used to compare two objects to determine their ordering with respect to each other.Interfacejava.utilCodeName One
ConcurrentModificationExceptionAn ConcurrentModificationException is thrown when a Collection is modified and an existing iterator on the Collection is used to modify theClassjava.utilCodeName One
DateThe class Date represents a specific instant in time, with millisecond precision.Classjava.utilCodeName One
DequeA kind of collection that can insert or remove element at both ends("double ended queue").Interfacejava.utilCodeName One
DictionaryNote: Do not use this class since it is obsolete.Classjava.utilCodeName One
EmptyStackExceptionThrown by methods in the Stack class to indicate that the stack is empty.Classjava.utilCodeName One
EnumerationAn object that implements the Enumeration interface generates a series of elements, one at a time.Interfacejava.utilCodeName One
EventListenerInterfacejava.utilCodeName One
EventListenerProxyThis abstract class provides a simple wrapper for objects of type EventListener.Classjava.utilCodeName One
HashMapHashMap is an implementation of Map.Classjava.utilCodeName One
HashSetHashSet is an implementation of a Set.Classjava.utilCodeName One
HashtableHashtable associates keys with values.Classjava.utilCodeName One
IdentityHashMapIdentityHashMap is a variant on HashMap which tests equality by reference instead of equality by value.Classjava.utilCodeName One
IteratorAn Iterator is used to sequence over a collection of objects.Interfacejava.utilCodeName One
LinkedHashMapLinkedHashMap is a variant of HashMap.Classjava.utilCodeName One
LinkedHashSetLinkedHashSet is a variant of HashSet.Classjava.utilCodeName One
LinkedListLinkedList is an implementation of List, backed by a linked list.Classjava.utilCodeName One
ListA List is a collection which maintains an ordering for its elements.Interfacejava.utilCodeName One
ListIteratorAn ListIterator is used to sequence over a List of objects.Interfacejava.utilCodeName One
MapA Map is a data structure consisting of a set of keys and values in which each key is mapped to a single value.Interfacejava.utilCodeName One
Map .EntryMap.Interfacejava.util.MapCodeName One
NavigableMapNavigableMap is a SortedMap with navigation methods answering the closest matches for specified item.Interfacejava.utilCodeName One
NavigableSetNavigableSet is a SortedSet with navigation methods answering the closest matches for specified item.Interfacejava.utilCodeName One
NoSuchElementExceptionThrown by the nextElement method of an Enumeration to indicate that there are no more elements in the enumeration.Classjava.utilCodeName One
ObservableObservable is used to notify a group of Observer objects when a change occurs.Classjava.utilCodeName One
ObserverObserver is the interface to be implemented by objects that receive notification of updates on an Observable object.Interfacejava.utilCodeName One
PriorityQueueA PriorityQueue holds elements on a priority heap, which orders the elements according to their natural order or according to the comparator specified atClassjava.utilCodeName One
QueueThis kind of collection provides advanced operations compared to basic collections, such as insertion, extraction, and inspection.Interfacejava.utilCodeName One
RandomAn instance of this class is used to generate a stream of pseudorandom numbers.Classjava.utilCodeName One
RandomAccessInterfacejava.utilCodeName One
SetA Set is a data structure which does not allow duplicate elements.Interfacejava.utilCodeName One
SortedMapA map that has its keys ordered.Interfacejava.utilCodeName One
SortedSetSortedSet is a Set which iterates over its elements in a sorted order.Interfacejava.utilCodeName One
StackStack is a Last-In/First-Out(LIFO) data structure which represents a stack of objects.Classjava.utilCodeName One
StringTokenizerThe StringTokenizer class allows an application to break a string into tokens by performing code point comparison.Classjava.utilCodeName One
TimerClassjava.utilCodeName One
TimerTaskClassjava.utilCodeName One
TimeZoneTimeZone represents a time zone offset, and also figures out daylight savings.Classjava.utilCodeName One
TreeMapTreeMap is an implementation of SortedMap.Classjava.utilCodeName One
TreeSetTreeSet is an implementation of SortedSet.Classjava.utilCodeName One
VectorVector is a variable size contiguous indexable array of objects.Classjava.utilCodeName One