Uses of Interface
org.apache.solr.common.MapSerializable
- 
Packages that use MapSerializable Package Description org.apache.solr.client.solrj Primary APIs for communicating with a Solr Server from a Java client.org.apache.solr.client.solrj.cloud Common classes for SolrCloud.org.apache.solr.client.solrj.impl Concrete implementations of client API classes.org.apache.solr.client.solrj.io Streaming Aggregation APIorg.apache.solr.client.solrj.io.eval Evaluators for the Streaming Aggregation APIorg.apache.solr.client.solrj.io.graph Streaming Graph Traversalsorg.apache.solr.client.solrj.io.stream Stream implementations for the Streaming Aggregation APIorg.apache.solr.client.solrj.io.stream.expr Expression language for the Streaming Aggregation APIorg.apache.solr.client.solrj.request Convenience classes for dealing with various types of Solr requests.org.apache.solr.client.solrj.request.beans Annotated Data objects used in V2 Requestsorg.apache.solr.client.solrj.response Convenience classes for dealing with various types of Solr responses.org.apache.solr.client.solrj.response.schema Convenience classes for dealing with Schema API responses.org.apache.solr.cluster.api API interfaces for core SolrCloud classesorg.apache.solr.common Common classes reused on both clients & server for dealing withdocuments to be indexedandresult documents.org.apache.solr.common.cloud Common Solr Cloud and ZooKeeper related classes reused on both clients & server.org.apache.solr.common.params Parameter constants and enumerations.org.apache.solr.common.util Common utility classes reused on both clients & server.
- 
- 
Uses of MapSerializable in org.apache.solr.client.solrjClasses in org.apache.solr.client.solrj that implement MapSerializable Modifier and Type Class Description classSolrQueryThis is an augmented SolrParams with get/set/add fields for common fields used in the Standard and Dismax request handlersclassSolrResponse
- 
Uses of MapSerializable in org.apache.solr.client.solrj.cloudClasses in org.apache.solr.client.solrj.cloud that implement MapSerializable Modifier and Type Class Description classShardTermsHold values of terms, this class is immutable.
- 
Uses of MapSerializable in org.apache.solr.client.solrj.implClasses in org.apache.solr.client.solrj.impl that implement MapSerializable Modifier and Type Class Description static classCloudSolrClient.RouteResponse<T extends LBSolrClient.Req>
- 
Uses of MapSerializable in org.apache.solr.client.solrj.ioClasses in org.apache.solr.client.solrj.io that implement MapSerializable Modifier and Type Class Description static classLang.LocalInputStreamclassTupleA simple abstraction of a record containing key/value pairs.
- 
Uses of MapSerializable in org.apache.solr.client.solrj.io.evalClasses in org.apache.solr.client.solrj.io.eval that implement MapSerializable Modifier and Type Class Description static classDbscanEvaluator.ClusterTuplestatic classKmeansEvaluator.ClusterTuplestatic classKnnRegressionEvaluator.KnnRegressionTuplestatic classLoessEvaluator.LoessRegressionTuplestatic classOLSRegressionEvaluator.MultipleRegressionTuplestatic classRegressionEvaluator.RegressionTuple
- 
Uses of MapSerializable in org.apache.solr.client.solrj.io.graphClasses in org.apache.solr.client.solrj.io.graph that implement MapSerializable Modifier and Type Class Description classGatherNodesStreamclassShortestPathStream
- 
Uses of MapSerializable in org.apache.solr.client.solrj.io.streamClasses in org.apache.solr.client.solrj.io.stream that implement MapSerializable Modifier and Type Class Description classBiJoinStreamJoins leftStream with rightStream based on a Equalitor.classCalculatorStreamclassCartesianProductStreamclassCellStreamclassCloudSolrStreamConnects to Zookeeper to pick replicas from a specific collection to send the query to.classCommitStreamSends a commit message to a SolrCloud collectionclassComplementStreamEmits tuples from streamA which do not exist in streamB.classCsvStreamclassDaemonStreamclassDeepRandomStreamConnects to Zookeeper to pick replicas from a specific collection to send the query to.classDeleteStreamUses tuples to identify the uniqueKey values of documents to be deletedclassDrillStreamclassEchoStreamclassEvalStreamclassExceptionStreamclassExecutorStreamThe executor function wraps a stream with Tuples containing Streaming Expressions and executes them in parallel.classFacet2DStreamclassFacetStreamThe FacetStream abstracts the output from the JSON facet API as a Stream of Tuples.classFeaturesSelectionStreamclassFetchStreamIterates over a stream and fetches additional fields from a specified collection.classGetStreamclassHashJoinStreamTakes two streams (fullStream and hashStream) and joins them similar to an InnerJoinStream.classHashRollupStreamclassHavingStreamThe HavingStream iterates over an internal stream and applies a BooleanOperation to each tuple.classInnerJoinStreamJoins leftStream with rightStream based on a Equalitor.classIntersectStreamEmits tuples from streamA which also exist in streamB.classJDBCStreamConnects to a datasource using a registered JDBC driver and execute a query.classJoinStreamDefines a JoinStream which can hold N streams, all joined with the same equalitorclassKnnStreamclassLeftOuterJoinStreamJoins leftStream with rightStream based on a Equalitor.classLetStreamclassListStreamclassMergeStreamMerges two or more streams together ordering the Tuples based on a Comparator.classModelStreamThe ModelStream retrieves a stored model from a Solr Cloud collection.classNoOpStreamA simple no-operation stream.classNullStreamThe NullStream Iterates over a TupleStream and eats the tuples.classOuterHashJoinStreamTakes two streams (fullStream and hashStream) and joins them similar to an LeftOuterJoinStream.classParallelListStreamclassParallelStreamThe ParallelStream decorates a TupleStream implementation and pushes it to N workers for parallel execution.classPlotStreamclassPriorityStreamThe priority function wraps two topics that represent high priority and low priority task queues.classPushBackStreamA TupleStream that allows a single Tuple to be pushed back onto the stream after it's been read.classRandomFacadeStreamclassRandomStreamThe RandomStream emits a stream of pseudo random Tuples that match the query parameters.classRankStreamIterates over a TupleStream and Ranks the topN tuples based on a Comparator.classReducerStreamIterates over a TupleStream and buffers Tuples that are equal based on a comparator.classRollupStreamclassScoreNodesStreamIterates over a gatherNodes() expression and scores the Tuples based on tf-idf.classSearchFacadeStreamConnects to Zookeeper to pick replicas from a specific collection to send the query to.classSearchStreamclassSelectStreamSelects fields from the incoming stream and applies optional field renaming.classShuffleStreamclassSignificantTermsStreamclassSolrStreamQueries a single Solr instance and maps SolrDocs to a Stream of Tuples.classSortStreamThe SortStream emits a stream of Tuples sorted by a Comparator.classSqlStreamclassStatsStreamclassTextLogitStreamprotected static classTextLogitStream.TermsStreamclassTimeSeriesStreamclassTopicStreamclassTsvStreamclassTupleStreamclassTupStreamclassUniqueStreamThe UniqueStream emits a unique stream of Tuples based on a Comparator.classUpdateStreamSends tuples emitted by a wrappedTupleStreamas updates to a SolrCloud collection.classZplotStream
- 
Uses of MapSerializable in org.apache.solr.client.solrj.io.stream.exprClasses in org.apache.solr.client.solrj.io.stream.expr that implement MapSerializable Modifier and Type Class Description classExplanationExplanation containing details about a expressionclassStreamExplanationExplanation containing details about a stream expression
- 
Uses of MapSerializable in org.apache.solr.client.solrj.request
- 
Uses of MapSerializable in org.apache.solr.client.solrj.request.beans
- 
Uses of MapSerializable in org.apache.solr.client.solrj.responseClasses in org.apache.solr.client.solrj.response that implement MapSerializable Modifier and Type Class Description classAnalysisResponseBaseA base class for all analysis responses.classCollectionAdminResponseclassConfigSetAdminResponseNo special handling at this time.static classConfigSetAdminResponse.ListclassCoreAdminResponseclassDelegationTokenResponseDelegation Token responsesstatic classDelegationTokenResponse.Cancelstatic classDelegationTokenResponse.Getstatic classDelegationTokenResponse.RenewclassDocumentAnalysisResponseA response that is returned by processing theDocumentAnalysisRequest.classFieldAnalysisResponseA response that is returned by processing theFieldAnalysisRequest.classHealthCheckResponseclassLukeResponseThis is an incomplete representation of the data returned from LukeclassQueryResponseclassSimpleSolrResponseclassSolrPingResponseclassSolrResponseBaseclassUpdateResponseTODO -- mostly a stub until we have a defined output formatclassV2Response
- 
Uses of MapSerializable in org.apache.solr.client.solrj.response.schemaClasses in org.apache.solr.client.solrj.response.schema that implement MapSerializable Modifier and Type Class Description classSchemaResponseThis class is used to wrap the response messages retrieved from Solr Schema API.static classSchemaResponse.CopyFieldsResponsestatic classSchemaResponse.DynamicFieldResponsestatic classSchemaResponse.DynamicFieldsResponsestatic classSchemaResponse.FieldResponsestatic classSchemaResponse.FieldsResponsestatic classSchemaResponse.FieldTypeResponsestatic classSchemaResponse.FieldTypesResponsestatic classSchemaResponse.GlobalSimilarityResponsestatic classSchemaResponse.SchemaNameResponsestatic classSchemaResponse.SchemaVersionResponsestatic classSchemaResponse.UniqueKeyResponsestatic classSchemaResponse.UpdateResponse
- 
Uses of MapSerializable in org.apache.solr.cluster.apiSubinterfaces of MapSerializable in org.apache.solr.cluster.api Modifier and Type Interface Description interfaceSimpleMap<T>A simplified read-only key-value structure.
- 
Uses of MapSerializable in org.apache.solr.commonSubinterfaces of MapSerializable in org.apache.solr.common Modifier and Type Interface Description interfaceMapWriterUse this class to push all entries of a Map into an output.Classes in org.apache.solr.common that implement MapSerializable Modifier and Type Class Description classConditionalKeyMapWriterclassConditionalMapWriterclassLinkedHashMapWriter<V>classMapWriterMapclassSolrDocumentA concrete representation of a document within a Solr index.classSolrDocumentBase<T,K>classSolrInputDocumentRepresent the field-value information needed to construct and index a Lucene Document.
- 
Uses of MapSerializable in org.apache.solr.common.cloudClasses in org.apache.solr.common.cloud that implement MapSerializable Modifier and Type Class Description classPerReplicaStatesThis represents the individual replica states in a collection This is an immutable object.static classPerReplicaStates.StateThe state of a replica as stored as a node under /collections/collection-name/state.json/replica-stateclassReplica
- 
Uses of MapSerializable in org.apache.solr.common.paramsClasses in org.apache.solr.common.params that implement MapSerializable Modifier and Type Class Description classAppendedSolrParamsSolrParams wrapper which acts similar to DefaultSolrParams except that it "appends" the values of multi-value params from both sub instances, so that all of the values are returned.classDefaultSolrParamsclassMapSolrParamsSolrParamsimplementation that can be built from and is backed by aMap.classModifiableSolrParamsThis class is similar toMultiMapSolrParamsexcept you can edit the parameters after it is initialized.classMultiMapSolrParamsclassRequiredSolrParamsThis is a simple wrapper to SolrParams that will throw a 400 exception if you ask for a parameter that does not exist.classSolrParamsSolrParams is designed to hold parameters to Solr, often from the request coming into Solr.
- 
Uses of MapSerializable in org.apache.solr.common.utilSubinterfaces of MapSerializable in org.apache.solr.common.util Modifier and Type Interface Description interfaceReflectMapWriterClasses in org.apache.solr.common.util that implement MapSerializable Modifier and Type Class Description classNamedList<T>A simple container class for modeling an ordered list of name/value pairs.classPair<T1,T2>classSimpleOrderedMap<T>SimpleOrderedMapis aNamedListwhere access by key is more important than maintaining order when it comes to representing the held data in other forms, as ResponseWriters normally do.classWrappedSimpleMap<T>
 
-